- abort(ConsumerWorkingSet, List<? extends PartitionKey>) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConcurrentPartitionConsumer
-
Resets the process state of the given partition keys, as they were not successfully processed, or discards the
partition if it has already been attempted the configured number of attempts.
- abortIfNotMet() - Method in interface io.cdap.cdap.api.schedule.ConstraintProgramScheduleBuilder
-
Specifies that the scheduler will abort the schedule execution if the configured constraint is not met.
- AbstractApplication<T extends Config> - Class in io.cdap.cdap.api.app
-
A support class for
Applications
which reduces repetition and results in
a more readable configuration.
- AbstractApplication() - Constructor for class io.cdap.cdap.api.app.AbstractApplication
-
- AbstractBuilder() - Constructor for class io.cdap.cdap.api.dataset.ExploreProperties.AbstractBuilder
-
- AbstractBuilder() - Constructor for class io.cdap.cdap.api.dataset.table.TableProperties.AbstractBuilder
-
- AbstractCloseableIterator<T> - Class in io.cdap.cdap.api.dataset.lib
-
- AbstractCloseableIterator() - Constructor for class io.cdap.cdap.api.dataset.lib.AbstractCloseableIterator
-
Constructor for use by subclasses.
- AbstractCondition - Class in io.cdap.cdap.api.workflow
-
The abstract class provides default implementation of the
Condition
methods for an easy extension
- AbstractCondition() - Constructor for class io.cdap.cdap.api.workflow.AbstractCondition
-
- AbstractCondition(String) - Constructor for class io.cdap.cdap.api.workflow.AbstractCondition
-
- AbstractCubeHttpHandler - Class in io.cdap.cdap.api.dataset.lib.cube
-
A basic implementation of
HttpServiceHandler
that provides endpoints to
explore and execute queries in
Cube
dataset.
- AbstractCubeHttpHandler() - Constructor for class io.cdap.cdap.api.dataset.lib.cube.AbstractCubeHttpHandler
-
- AbstractCustomAction - Class in io.cdap.cdap.api.customaction
-
This abstract class provides a default implementation of
CustomAction
methods for easy extensions.
- AbstractCustomAction() - Constructor for class io.cdap.cdap.api.customaction.AbstractCustomAction
-
- AbstractCustomAction(String) - Constructor for class io.cdap.cdap.api.customaction.AbstractCustomAction
-
- AbstractDataset - Class in io.cdap.cdap.api.dataset.lib
-
Handy abstract implementation of
Dataset
that acts on a list of underlying datasets and
implements
TransactionAware
and
MeteredDataset
interfaces by propagating corresponded
logic to each dataset in a list when possible.
- AbstractDataset(String, Dataset, Dataset...) - Constructor for class io.cdap.cdap.api.dataset.lib.AbstractDataset
-
- AbstractDatasetDefinition<D extends Dataset,A extends DatasetAdmin> - Class in io.cdap.cdap.api.dataset.lib
-
- AbstractDatasetDefinition(String) - Constructor for class io.cdap.cdap.api.dataset.lib.AbstractDatasetDefinition
-
Ctor that takes in name of this dataset type.
- AbstractFieldAccessor - Class in io.cdap.cdap.internal.io
-
- AbstractFieldAccessor(Type) - Constructor for class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- AbstractHttpServiceHandler<T extends HttpServiceContext,V extends HttpServiceConfigurer> - Class in io.cdap.cdap.api.service.http
-
- AbstractHttpServiceHandler() - Constructor for class io.cdap.cdap.api.service.http.AbstractHttpServiceHandler
-
- AbstractMapReduce - Class in io.cdap.cdap.api.mapreduce
-
This abstract class provides a default implementation of
MapReduce
methods for easy extension.
- AbstractMapReduce() - Constructor for class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
- AbstractPartitionConsumer - Class in io.cdap.cdap.api.dataset.lib.partitioned
-
Abstract implementation of PartitionConsumer, which manages state persistence and serialization/deserialization
before delegating to the abstract methods.
- AbstractPartitionConsumer(PartitionedFileSet, StatePersistor) - Constructor for class io.cdap.cdap.api.dataset.lib.partitioned.AbstractPartitionConsumer
-
Creates an instance of PartitionConsumer.
- AbstractPartitionConsumer(PartitionedFileSet, StatePersistor, ConsumerConfiguration) - Constructor for class io.cdap.cdap.api.dataset.lib.partitioned.AbstractPartitionConsumer
-
Creates an instance of PartitionConsumer.
- AbstractPluginConfigurable<T extends PluginConfigurer & DatasetConfigurer> - Class in io.cdap.cdap.internal.api
-
Helper methods to add plugins to Programs.
- AbstractPluginConfigurable() - Constructor for class io.cdap.cdap.internal.api.AbstractPluginConfigurable
-
- AbstractProgramDatasetConfigurable<T extends DatasetConfigurer> - Class in io.cdap.cdap.internal.api
-
Helper methods to help add stream/dataset to Programs.
- AbstractProgramDatasetConfigurable() - Constructor for class io.cdap.cdap.internal.api.AbstractProgramDatasetConfigurable
-
- AbstractProgramSpecification - Class in io.cdap.cdap.api
-
Base abstract class for
ProgramSpecification
which contains common information for various program
specifications.
- AbstractProgramSpecification(String, String, String, Map<String, Plugin>) - Constructor for class io.cdap.cdap.api.AbstractProgramSpecification
-
- AbstractSchemaGenerator - Class in io.cdap.cdap.internal.io
-
An abstract base class for generating schema.
- AbstractSchemaGenerator() - Constructor for class io.cdap.cdap.internal.io.AbstractSchemaGenerator
-
- AbstractService<T extends ServiceConfigurer,V extends ServiceContext> - Class in io.cdap.cdap.api.service
-
An abstract implementation of
Service
.
- AbstractService() - Constructor for class io.cdap.cdap.api.service.AbstractService
-
- AbstractSpark - Class in io.cdap.cdap.api.spark
-
This abstract class provides a default implementation of
Spark
methods for easy extension.
- AbstractSpark() - Constructor for class io.cdap.cdap.api.spark.AbstractSpark
-
- AbstractWorker - Class in io.cdap.cdap.api.worker
-
Extend this class to add workers.
- AbstractWorker() - Constructor for class io.cdap.cdap.api.worker.AbstractWorker
-
- AbstractWorkflow - Class in io.cdap.cdap.api.workflow
-
Provides a default implementation of
Workflow
methods for easy extension.
- AbstractWorkflow() - Constructor for class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- accept(PartitionDetail) - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.PartitionAcceptor
-
- accept(PartitionDetail) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.PartitionAcceptor.Limit
-
- AccessException - Exception in io.cdap.cdap.api.security
-
General exception thrown from security calls in case of any problems.
- AccessException() - Constructor for exception io.cdap.cdap.api.security.AccessException
-
- AccessException(String) - Constructor for exception io.cdap.cdap.api.security.AccessException
-
- AccessException(String, Throwable) - Constructor for exception io.cdap.cdap.api.security.AccessException
-
- AccessException(Throwable) - Constructor for exception io.cdap.cdap.api.security.AccessException
-
- AccessException(String, Throwable, boolean, boolean) - Constructor for exception io.cdap.cdap.api.security.AccessException
-
- add(String, String) - Method in class io.cdap.cdap.api.dataset.DatasetProperties.Builder
-
Adds a property.
- add(String, int) - Method in class io.cdap.cdap.api.dataset.DatasetProperties.Builder
-
Adds a property.
- add(String, long) - Method in class io.cdap.cdap.api.dataset.DatasetProperties.Builder
-
Adds a property.
- add(CubeFact) - Method in interface io.cdap.cdap.api.dataset.lib.cube.Cube
-
- add(Collection<? extends CubeFact>) - Method in interface io.cdap.cdap.api.dataset.lib.cube.Cube
-
- add(DatasetDefinition) - Method in interface io.cdap.cdap.api.dataset.module.DatasetDefinitionRegistry
-
- add(byte[], long) - Method in class io.cdap.cdap.api.dataset.table.Increment
-
Adds a column and sets the column's value.
- add(String, long) - Method in class io.cdap.cdap.api.dataset.table.Increment
-
Adds a column and sets the column's value.
- add(byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(byte[], String) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(byte[], boolean) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(byte[], short) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(byte[], int) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(byte[], long) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(byte[], float) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(byte[], double) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(String, byte[]) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(String, String) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(String, boolean) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(String, short) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(String, int) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(String, long) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(String, float) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(String, double) - Method in class io.cdap.cdap.api.dataset.table.Put
-
Write a value to a column.
- add(byte[], byte[]...) - Method in class io.cdap.cdap.api.dataset.table.RowColumns
-
Specifies column(s) to be included.
- add(byte[][]) - Method in class io.cdap.cdap.api.dataset.table.RowColumns
-
Specifies column(s) to be included.
- add(String, String...) - Method in class io.cdap.cdap.api.dataset.table.RowColumns
-
Specifies column(s) to be included.
- add(String[]) - Method in class io.cdap.cdap.api.dataset.table.RowColumns
-
Specifies column(s) to be included.
- add(String, PluginPropertyField) - Method in class io.cdap.cdap.api.plugin.PluginClass.Builder
-
Adds a property
- add(String, String) - Method in class io.cdap.cdap.api.plugin.PluginProperties.Builder
-
Adds a property
- addAction(CustomAction) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- addAction(CustomAction) - Method in interface io.cdap.cdap.api.workflow.WorkflowConditionConfigurer
-
- addAction(CustomAction) - Method in interface io.cdap.cdap.api.workflow.WorkflowConfigurer
-
Adds a custom action as a next sequential step in the
Workflow
- addAction(CustomAction) - Method in interface io.cdap.cdap.api.workflow.WorkflowForkConfigurer
-
Adds custom action a a next sequential step to the current branch of the
WorkflowForkNode
- addAll(Map<String, String>) - Method in class io.cdap.cdap.api.dataset.DatasetProperties.Builder
-
Adds multiple properties.
- addAll(Map<String, PluginPropertyField>) - Method in class io.cdap.cdap.api.plugin.PluginClass.Builder
-
Adds multiple properties.
- addAll(Map<String, String>) - Method in class io.cdap.cdap.api.plugin.PluginProperties.Builder
-
Adds multiple properties.
- addApp(ApplicationClass) - Method in class io.cdap.cdap.api.artifact.ArtifactClasses.Builder
-
- addApps(ApplicationClass...) - Method in class io.cdap.cdap.api.artifact.ArtifactClasses.Builder
-
- addApps(Iterable<ApplicationClass>) - Method in class io.cdap.cdap.api.artifact.ArtifactClasses.Builder
-
- addDatasetModule(String, Class<? extends DatasetModule>) - Method in interface io.cdap.cdap.api.DatasetConfigurer
-
Adds a
DatasetModule
to be deployed automatically (if absent in the CDAP namespace) during application
deployment.
- addDatasetModule(String, Class<? extends DatasetModule>) - Method in class io.cdap.cdap.internal.api.AbstractProgramDatasetConfigurable
-
- addDatasetModule(String, Class<? extends DatasetModule>) - Method in class io.cdap.cdap.internal.api.DefaultDatasetConfigurer
-
- addDatasetModules(Map<String, String>) - Method in class io.cdap.cdap.internal.api.DefaultDatasetConfigurer
-
- addDatasetSpecs(Map<String, DatasetCreationSpec>) - Method in class io.cdap.cdap.internal.api.DefaultDatasetConfigurer
-
- addDatasetType(Class<? extends Dataset>) - Method in interface io.cdap.cdap.api.DatasetConfigurer
-
- addDatasetType(Class<? extends Dataset>) - Method in class io.cdap.cdap.internal.api.AbstractProgramDatasetConfigurable
-
- addDatasetType(Class<? extends Dataset>) - Method in class io.cdap.cdap.internal.api.DefaultDatasetConfigurer
-
- addDimensionValue(String, String) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeFact
-
- addDimensionValues(Map<String, String>) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeFact
-
Adds multiple dimensionValues to this
CubeFact
.
- addFact(HttpServiceRequest, HttpServiceResponder) - Method in class io.cdap.cdap.api.dataset.lib.cube.AbstractCubeHttpHandler
-
- addField(String, Partitioning.FieldType) - Method in class io.cdap.cdap.api.dataset.lib.Partitioning.Builder
-
Add a field with a given name and type.
- addField(String, Comparable) - Method in class io.cdap.cdap.api.dataset.lib.PartitionKey.Builder
-
Add a field with a given name and value.
- addHandler(HttpServiceHandler) - Method in class io.cdap.cdap.api.service.AbstractService
-
Add handler to the Service.
- addHandlers(Iterable<? extends HttpServiceHandler>) - Method in class io.cdap.cdap.api.service.AbstractService
-
Add a list of handlers to the Service.
- addHandlers(Iterable<? extends HttpServiceHandler>) - Method in interface io.cdap.cdap.api.service.ServiceConfigurer
-
Add a a list of request handlers to the Service.
- addInput(Input) - Method in interface io.cdap.cdap.api.mapreduce.MapReduceContext
-
Updates the input configuration of this MapReduce job to use the specified
Input
.
- addInput(Input, Class<?>) - Method in interface io.cdap.cdap.api.mapreduce.MapReduceContext
-
Updates the input configuration of this MapReduce job to use the specified
Input
.
- addInputPartition(Map<String, String>, Partition) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Sets a partition as input for a PartitionedFileSet.
- addInputPartitions(Map<String, String>, Iterator<? extends Partition>) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Sets partitions as input for a PartitionedFileSet.
- addInputPartitions(Map<String, String>, Iterable<? extends Partition>) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Sets partitions as input for a PartitionedFileSet.
- addInputPath(Map<String, String>, String) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetArguments
-
Add an input path in the runtime arguments for a file dataset.
- addIntField(String) - Method in class io.cdap.cdap.api.dataset.lib.Partitioning.Builder
-
Add field of type INT.
- addIntField(String, int) - Method in class io.cdap.cdap.api.dataset.lib.PartitionKey.Builder
-
Add field of type INT.
- addLongField(String) - Method in class io.cdap.cdap.api.dataset.lib.Partitioning.Builder
-
Add field of type LONG.
- addLongField(String, long) - Method in class io.cdap.cdap.api.dataset.lib.PartitionKey.Builder
-
Add field of type LONG.
- addMapReduce(MapReduce) - Method in class io.cdap.cdap.api.app.AbstractApplication
-
- addMapReduce(MapReduce) - Method in interface io.cdap.cdap.api.app.ApplicationConfigurer
-
- addMapReduce(String) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
Adds a MapReduce program to the
Workflow
.
- addMapReduce(String) - Method in interface io.cdap.cdap.api.workflow.WorkflowConditionConfigurer
-
- addMapReduce(String) - Method in interface io.cdap.cdap.api.workflow.WorkflowConfigurer
-
Adds a MapReduce program as a next sequential step in the
Workflow
.
- addMapReduce(String) - Method in interface io.cdap.cdap.api.workflow.WorkflowForkConfigurer
-
Adds a MapReduce program as a next sequential step to the current branch of the
WorkflowForkNode
- addMeasurement(String, MeasureType, long) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeFact
-
- addMeasurement(Measurement) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeFact
-
- addMeasurements(Collection<Measurement>) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeFact
-
- addMetadata(PartitionKey, String, String) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Adds a new metadata entry for a particular partition.
- addMetadata(PartitionKey, Map<String, String>) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Adds a set of new metadata entries for a particular partition.
- addMetadata(long, String, String) - Method in interface io.cdap.cdap.api.dataset.lib.TimePartitionedFileSet
-
Adds a new metadata entry for a particular partition.
- addMetadata(long, Map<String, String>) - Method in interface io.cdap.cdap.api.dataset.lib.TimePartitionedFileSet
-
Adds a set of new metadata entries for a particular partition
Note that existing entries can not be updated.
- addOutput(Output) - Method in interface io.cdap.cdap.api.mapreduce.MapReduceContext
-
Updates the output configuration of this MapReduce job to use the specified
Output
.
- addPartition(PartitionKey) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerWorkingSet
-
Adds a new partition to the working set.
- addPartition(PartitionKey, String) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Add a partition for a given partition key, stored at a given path (relative to the file set's base path).
- addPartition(PartitionKey, String, Map<String, String>) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Add a partition for a given partition key, stored at a given path (relative to the file set's base path),
with the given metadata.
- addPartition() - Method in interface io.cdap.cdap.api.dataset.lib.PartitionOutput
-
Add the partition to the partitioned file set.
- addPartition(long, String) - Method in interface io.cdap.cdap.api.dataset.lib.TimePartitionedFileSet
-
Add a partition for a given time, stored at a given path (relative to the file set's base path).
- addPartition(long, String, Map<String, String>) - Method in interface io.cdap.cdap.api.dataset.lib.TimePartitionedFileSet
-
Add a partition for a given time, stored at a given path (relative to the file set's base path),
with given metadata.
- addPlugin(PluginClass) - Method in class io.cdap.cdap.api.artifact.ArtifactClasses.Builder
-
- addPlugins(PluginClass...) - Method in class io.cdap.cdap.api.artifact.ArtifactClasses.Builder
-
- addPlugins(Iterable<PluginClass>) - Method in class io.cdap.cdap.api.artifact.ArtifactClasses.Builder
-
- addProperties(MetadataEntity, Map<String, String>) - Method in interface io.cdap.cdap.api.metadata.MetadataWriter
-
- addRangeCondition(String, T, T) - Method in class io.cdap.cdap.api.dataset.lib.PartitionFilter.Builder
-
Add a condition for a given field name with an inclusive lower and an exclusive upper bound.
- addScope(Scope, String, Map<String, String>) - Static method in class io.cdap.cdap.api.common.RuntimeArguments
-
Add a scope prefix to all arguments.
- addScope(Scope, String, String) - Static method in class io.cdap.cdap.api.common.RuntimeArguments
-
Add a scope prefix to an argument name.
- addScope(String, String, String) - Static method in class io.cdap.cdap.api.common.RuntimeArguments
-
Add a scope prefix to an argument name.
- addService(Service) - Method in class io.cdap.cdap.api.app.AbstractApplication
-
- addService(String, HttpServiceHandler, HttpServiceHandler...) - Method in class io.cdap.cdap.api.app.AbstractApplication
-
- addService(Service) - Method in interface io.cdap.cdap.api.app.ApplicationConfigurer
-
Adds a custom
Service
to the Application.
- addSpark(Spark) - Method in class io.cdap.cdap.api.app.AbstractApplication
-
- addSpark(Spark) - Method in interface io.cdap.cdap.api.app.ApplicationConfigurer
-
Adds a
Spark
job to the Application.
- addSpark(String) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- addSpark(String) - Method in interface io.cdap.cdap.api.workflow.WorkflowConditionConfigurer
-
- addSpark(String) - Method in interface io.cdap.cdap.api.workflow.WorkflowConfigurer
-
Adds a Spark program as a next sequential step in the
Workflow
.
- addSpark(String) - Method in interface io.cdap.cdap.api.workflow.WorkflowForkConfigurer
-
Adds a Spark program as a next sequential step to the current branch of the
WorkflowForkNode
- addStringField(String) - Method in class io.cdap.cdap.api.dataset.lib.Partitioning.Builder
-
Add field of type STRING.
- addStringField(String, String) - Method in class io.cdap.cdap.api.dataset.lib.PartitionKey.Builder
-
Add field of type STRING.
- addTags(MetadataEntity, String...) - Method in interface io.cdap.cdap.api.metadata.MetadataWriter
-
- addTags(MetadataEntity, Iterable<String>) - Method in interface io.cdap.cdap.api.metadata.MetadataWriter
-
- addValueCondition(String, T) - Method in class io.cdap.cdap.api.dataset.lib.PartitionFilter.Builder
-
Add a condition that matches by equality.
- addWorker(Worker) - Method in class io.cdap.cdap.api.app.AbstractApplication
-
- addWorker(Worker) - Method in interface io.cdap.cdap.api.app.ApplicationConfigurer
-
Adds a
Worker
to the Application.
- addWorkflow(Workflow) - Method in class io.cdap.cdap.api.app.AbstractApplication
-
- addWorkflow(Workflow) - Method in interface io.cdap.cdap.api.app.ApplicationConfigurer
-
- Admin - Interface in io.cdap.cdap.api
-
This interface provides methods for operational calls from within a CDAP application.
- AggregationFunction - Enum in io.cdap.cdap.api.dataset.lib.cube
-
Function to be used when aggregating multiple data points.
- AggregationOption - Enum in io.cdap.cdap.api.dataset.lib.cube
-
The metrics aggregation option.
- alias(String) - Method in class io.cdap.cdap.api.data.batch.Input
-
Sets an alias to be used as the input name.
- alias(String) - Method in class io.cdap.cdap.api.data.batch.Output
-
Sets an alias to be used as the output name.
- ALL - Static variable in enum io.cdap.cdap.api.metadata.MetadataScope
-
- also() - Method in interface io.cdap.cdap.api.workflow.WorkflowForkConfigurer
-
- ALWAYS_MATCH - Static variable in class io.cdap.cdap.api.dataset.lib.PartitionFilter
-
- and(Trigger...) - Method in interface io.cdap.cdap.api.schedule.TriggerFactory
-
Creates a trigger which is satisfied when all of the given triggers are satisfied.
- append(String, String) - Method in class io.cdap.cdap.api.metadata.MetadataEntity.Builder
-
- appendAsType(String, String) - Method in class io.cdap.cdap.api.metadata.MetadataEntity.Builder
-
- Application<T extends Config> - Interface in io.cdap.cdap.api.app
-
Defines a CDAP Application.
- APPLICATION - Static variable in class io.cdap.cdap.api.metadata.MetadataEntity
-
- ApplicationClass - Class in io.cdap.cdap.api.artifact
-
Contains information about an Application class.
- ApplicationClass(String, String, Schema) - Constructor for class io.cdap.cdap.api.artifact.ApplicationClass
-
- ApplicationClass(String, String, Schema, Requirements) - Constructor for class io.cdap.cdap.api.artifact.ApplicationClass
-
- ApplicationConfigUpdateAction - Enum in io.cdap.cdap.api.app
-
Possible update actions for application config.
- ApplicationConfigurer - Interface in io.cdap.cdap.api.app
-
Configures a CDAP Application.
- ApplicationContext<T extends Config> - Interface in io.cdap.cdap.api.app
-
Provides access to the environment, application configuration, and application (deployment) arguments.
- ApplicationSpecification - Interface in io.cdap.cdap.api.app
-
Application Specification used in core code.
- ApplicationUpdateContext - Interface in io.cdap.cdap.api.app
-
Context for updating Application configs.
- ApplicationUpdateResult<T extends Config> - Class in io.cdap.cdap.api.app
-
Stores results of upgrading an application config.
- ApplicationUpdateResult(T) - Constructor for class io.cdap.cdap.api.app.ApplicationUpdateResult
-
- apply(T) - Method in interface io.cdap.cdap.api.Predicate
-
Returns the result of applying this predicate to input
.
- ARTIFACT - Static variable in class io.cdap.cdap.api.metadata.MetadataEntity
-
- ArtifactClasses - Class in io.cdap.cdap.api.artifact
-
Classes contained in an artifact, such as plugin classes and application classes.
- ArtifactClasses.Builder - Class in io.cdap.cdap.api.artifact
-
Builder to more easily add application and plugin classes, and in the future, program and dataset classes.
- ArtifactId - Class in io.cdap.cdap.api.artifact
-
Uniquely describes an artifact within a namespace.
- ArtifactId(String, ArtifactVersion, ArtifactScope) - Constructor for class io.cdap.cdap.api.artifact.ArtifactId
-
- ArtifactInfo - Class in io.cdap.cdap.api.artifact
-
Represents an artifact returned by /artifacts/{artifact-name}/versions/{artifact-version}.
- ArtifactInfo(ArtifactId, ArtifactClasses, Map<String, String>) - Constructor for class io.cdap.cdap.api.artifact.ArtifactInfo
-
- ArtifactInfo(ArtifactId, ArtifactClasses, Map<String, String>, Set<ArtifactRange>) - Constructor for class io.cdap.cdap.api.artifact.ArtifactInfo
-
- ArtifactInfo(String, String, ArtifactScope, ArtifactClasses, Map<String, String>) - Constructor for class io.cdap.cdap.api.artifact.ArtifactInfo
-
- ArtifactInfo(String, String, ArtifactScope, ArtifactClasses, Map<String, String>, Set<ArtifactRange>) - Constructor for class io.cdap.cdap.api.artifact.ArtifactInfo
-
- ArtifactManager - Interface in io.cdap.cdap.api.artifact
-
Provides access to artifacts
- ArtifactRange - Class in io.cdap.cdap.api.artifact
-
Represents a range of versions for an artifact.
- ArtifactRange(String, String, ArtifactVersion, ArtifactVersion) - Constructor for class io.cdap.cdap.api.artifact.ArtifactRange
-
- ArtifactRange(String, String, ArtifactVersion, boolean, ArtifactVersion, boolean) - Constructor for class io.cdap.cdap.api.artifact.ArtifactRange
-
- ArtifactRange(String, String, ArtifactVersionRange) - Constructor for class io.cdap.cdap.api.artifact.ArtifactRange
-
- ArtifactScope - Enum in io.cdap.cdap.api.artifact
-
The scope of an artifact.
- ArtifactSummary - Class in io.cdap.cdap.api.artifact
-
Represents an artifact returned by /artifacts and /artifacts/{artifact-name}.
- ArtifactSummary(String, String) - Constructor for class io.cdap.cdap.api.artifact.ArtifactSummary
-
- ArtifactSummary(String, String, ArtifactScope) - Constructor for class io.cdap.cdap.api.artifact.ArtifactSummary
-
- ArtifactVersion - Class in io.cdap.cdap.api.artifact
-
Represents version of an artifact.
- ArtifactVersion(String) - Constructor for class io.cdap.cdap.api.artifact.ArtifactVersion
-
Constructs an instance by parsing the given string.
- ArtifactVersion(String, boolean) - Constructor for class io.cdap.cdap.api.artifact.ArtifactVersion
-
Constructs an instance by parsing the given string.
- ArtifactVersionRange - Class in io.cdap.cdap.api.artifact
-
Represents a version range of an artifact.
- ArtifactVersionRange(ArtifactVersion, boolean, ArtifactVersion, boolean) - Constructor for class io.cdap.cdap.api.artifact.ArtifactVersionRange
-
- asMap() - Method in class io.cdap.cdap.api.dataset.lib.PartitionMetadata
-
- assertInProgress(ConsumablePartition) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConcurrentPartitionConsumer
-
ensure that caller doesn't try to commit/abort a partition that isn't in progress
- call(DatasetContext) - Method in interface io.cdap.cdap.api.TxCallable
-
- CallerClassSecurityManager - Class in io.cdap.cdap.internal.lang
-
- Category - Annotation Type in io.cdap.cdap.api.annotation
-
Annotates the category for a plugin.
- child(Map<String, String>) - Method in interface io.cdap.cdap.api.metrics.Metrics
-
Get the child
Metrics
by adding specified tags to the current metrics context.
- classes() - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken.TypeSet
-
Returns the types that are classes.
- ClientLocalizationContext - Interface in io.cdap.cdap.api
-
Context that adds the capability to localize resources in programs.
- close() - Method in class io.cdap.cdap.api.artifact.CloseableClassLoader
-
- close() - Method in class io.cdap.cdap.api.data.batch.RecordScanner
-
Close the record reader.
- close() - Method in class io.cdap.cdap.api.data.batch.SplitReader
-
Close the record reader.
- close() - Method in class io.cdap.cdap.api.data.batch.SplitReaderAdapter
-
- close() - Method in class io.cdap.cdap.api.data.batch.SplitReaderBase
-
- close() - Method in class io.cdap.cdap.api.dataset.lib.AbstractDataset
-
- close() - Method in interface io.cdap.cdap.api.dataset.lib.CloseableIterator
-
- close() - Method in class io.cdap.cdap.api.dataset.lib.CompositeDatasetAdmin
-
- close() - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable.KeyValueScanner
-
- close() - Method in interface io.cdap.cdap.api.dataset.table.Scanner
-
Closes the scanner and releases any resources.
- close() - Method in class io.cdap.cdap.internal.dataset.DatasetRuntimeContext
-
- CloseableClassLoader - Class in io.cdap.cdap.api.artifact
-
- CloseableClassLoader(ClassLoader, Closeable) - Constructor for class io.cdap.cdap.api.artifact.CloseableClassLoader
-
- CloseableIterator<T> - Interface in io.cdap.cdap.api.dataset.lib
-
Iterator that can be closed.
- commit(ConsumerWorkingSet, List<? extends PartitionKey>) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConcurrentPartitionConsumer
-
Removes the given partition keys from the working set, as they have been successfully processed.
- commitTx() - Method in class io.cdap.cdap.api.dataset.lib.AbstractDataset
-
- ComparableCodec - Class in io.cdap.cdap.api.dataset.lib.partitioned
-
Responsible for serialization and deserialization of
Comparable
.
- ComparableCodec() - Constructor for class io.cdap.cdap.api.dataset.lib.partitioned.ComparableCodec
-
- compareAndSwap(byte[], byte[], byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Perform a swap operation by primary key.
- compareAndSwap(byte[], byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
Compares-and-swaps (atomically) the value of the specified row and column
by looking for the specified expected value and, if found, replacing with
the specified new value.
- compareAndSwap(byte[], byte[], byte[], byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Compares-and-swaps (atomically) the value of the specified row and column by looking for
an expected value and, if found, replacing it with the new value.
- compareTo(ArtifactId) - Method in class io.cdap.cdap.api.artifact.ArtifactId
-
- compareTo(ArtifactVersion) - Method in class io.cdap.cdap.api.artifact.ArtifactVersion
-
- compareTo(TimeValue) - Method in class io.cdap.cdap.api.dataset.lib.cube.TimeValue
-
- compareTo(Object) - Method in class io.cdap.cdap.api.PlatformInfo.Version
-
- complete() - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.ConsumablePartition
-
Marks the ProcessState as COMPLETED
- complete() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.DefaultConsumablePartition
-
- CompositeDatasetAdmin - Class in io.cdap.cdap.api.dataset.lib
-
- CompositeDatasetAdmin(Map<String, ? extends DatasetAdmin>) - Constructor for class io.cdap.cdap.api.dataset.lib.CompositeDatasetAdmin
-
Constructor that takes list of dataset admins
- CompositeDatasetDefinition<D extends Dataset> - Class in io.cdap.cdap.api.dataset.lib
-
Handy implementation of
DatasetDefinition
that implements basic methods by delegating logic execution to
underlying dataset definitions.
- CompositeDatasetDefinition(String, Map<String, ? extends DatasetDefinition>) - Constructor for class io.cdap.cdap.api.dataset.lib.CompositeDatasetDefinition
-
Constructor that takes an info about underlying datasets
- CompositeDatasetDefinition(String, String, DatasetDefinition) - Constructor for class io.cdap.cdap.api.dataset.lib.CompositeDatasetDefinition
-
Constructor that takes one underlying dataset.
- CompositeDatasetDefinition(String, String, DatasetDefinition, String, DatasetDefinition) - Constructor for class io.cdap.cdap.api.dataset.lib.CompositeDatasetDefinition
-
Constructor that takes two underlying datasets.
- computeNext() - Method in class io.cdap.cdap.api.dataset.lib.AbstractCloseableIterator
-
Returns the next element.
- concatenatePartition(PartitionKey) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Asynchronous operation to concatenate the partition in Hive.
- ConcurrentPartitionConsumer - Class in io.cdap.cdap.api.dataset.lib.partitioned
-
A
PartitionConsumer
that supports multiple instances consuming the same set of partitions by using a
working set of partitions, and keeping track of their progress state during processing of those partitions.
- ConcurrentPartitionConsumer(PartitionedFileSet, StatePersistor) - Constructor for class io.cdap.cdap.api.dataset.lib.partitioned.ConcurrentPartitionConsumer
-
- ConcurrentPartitionConsumer(PartitionedFileSet, StatePersistor, ConsumerConfiguration) - Constructor for class io.cdap.cdap.api.dataset.lib.partitioned.ConcurrentPartitionConsumer
-
- condition(Predicate<WorkflowContext>) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- condition(Condition) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- Condition - Interface in io.cdap.cdap.api.workflow
-
Defines configurable condition in the Workflow.
- condition(Predicate<WorkflowContext>) - Method in interface io.cdap.cdap.api.workflow.WorkflowConditionConfigurer
-
Adds a nested condition to the current condition.
- condition(Condition) - Method in interface io.cdap.cdap.api.workflow.WorkflowConditionConfigurer
-
Adds a nested condition to the current condition.
- condition(Predicate<WorkflowContext>) - Method in interface io.cdap.cdap.api.workflow.WorkflowConfigurer
-
- condition(Condition) - Method in interface io.cdap.cdap.api.workflow.WorkflowConfigurer
-
- condition(Predicate<WorkflowContext>) - Method in interface io.cdap.cdap.api.workflow.WorkflowForkConfigurer
-
Adds a condition to the current branch of the fork.
- condition(Condition) - Method in interface io.cdap.cdap.api.workflow.WorkflowForkConfigurer
-
Adds a condition to the current branch of the fork.
- ConditionCodec - Class in io.cdap.cdap.api.dataset.lib
-
- ConditionCodec() - Constructor for class io.cdap.cdap.api.dataset.lib.ConditionCodec
-
- ConditionConfigurer - Interface in io.cdap.cdap.api.workflow
-
- ConditionSpecification - Interface in io.cdap.cdap.api.workflow
-
Specification for the condition that will be executed as a part of
Workflow
.
- Config - Class in io.cdap.cdap.api
-
Configuration class of an configurable entity, such as
Application
.
- Config() - Constructor for class io.cdap.cdap.api.Config
-
- configure() - Method in class io.cdap.cdap.api.app.AbstractApplication
-
Override this method to declare and configure the application.
- configure(ApplicationConfigurer, ApplicationContext<T>) - Method in class io.cdap.cdap.api.app.AbstractApplication
-
- configure(ApplicationConfigurer, ApplicationContext<T>) - Method in interface io.cdap.cdap.api.app.Application
-
Configures the Application.
- configure(CustomActionConfigurer) - Method in class io.cdap.cdap.api.customaction.AbstractCustomAction
-
- configure() - Method in class io.cdap.cdap.api.customaction.AbstractCustomAction
-
- configure(CustomActionConfigurer) - Method in interface io.cdap.cdap.api.customaction.CustomAction
-
Configure the custom action.
- configure(String, DatasetProperties) - Method in interface io.cdap.cdap.api.dataset.DatasetDefinition
-
Configures new instance of the dataset.
- configure() - Method in class io.cdap.cdap.api.dataset.lib.app.partitioned.PartitionExploreCorrector
-
- configure(String, DatasetProperties) - Method in class io.cdap.cdap.api.dataset.lib.CompositeDatasetDefinition
-
- configure(String, DatasetProperties) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTableDefinition
-
- configure(MapReduceConfigurer) - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
- configure() - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
Override this method to configure this
MapReduce
job.
- configure(MapReduceConfigurer) - Method in interface io.cdap.cdap.api.mapreduce.MapReduce
-
- configure(T) - Method in class io.cdap.cdap.api.service.AbstractService
-
- configure() - Method in class io.cdap.cdap.api.service.AbstractService
-
Implements this method to configure this Service.
- configure() - Method in class io.cdap.cdap.api.service.BasicService
-
- configure() - Method in class io.cdap.cdap.api.service.http.AbstractHttpServiceHandler
-
This can be overridden in child classes to add custom user properties during configure time.
- configure(V) - Method in class io.cdap.cdap.api.service.http.AbstractHttpServiceHandler
-
- configure(V) - Method in interface io.cdap.cdap.api.service.http.HttpServiceHandler
-
- configure(T) - Method in interface io.cdap.cdap.api.service.Service
-
- configure() - Method in class io.cdap.cdap.api.SingleRunnableApplication
-
- configure(SparkConfigurer) - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
- configure() - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
Override this method to configure this
Spark
job.
- configure(SparkConfigurer) - Method in interface io.cdap.cdap.api.spark.Spark
-
- configure(WorkerConfigurer) - Method in class io.cdap.cdap.api.worker.AbstractWorker
-
- configure() - Method in class io.cdap.cdap.api.worker.AbstractWorker
-
Configures the worker.
- configure(WorkerConfigurer) - Method in interface io.cdap.cdap.api.worker.Worker
-
Configure a Worker
.
- configure() - Method in class io.cdap.cdap.api.workflow.AbstractCondition
-
- configure(ConditionConfigurer) - Method in class io.cdap.cdap.api.workflow.AbstractCondition
-
- configure(WorkflowConfigurer) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- configure() - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
Override this method to configure this
Workflow
.
- configure(ConditionConfigurer) - Method in interface io.cdap.cdap.api.workflow.Condition
-
Configures the condition.
- configure(WorkflowConfigurer) - Method in interface io.cdap.cdap.api.workflow.Workflow
-
- ConflictDetection - Enum in io.cdap.cdap.api.dataset.table
-
Conflict detection level of a table.
- Constraint - Interface in io.cdap.cdap.internal.schedule.constraint
-
A constraint that is checked before executing a schedule.
- ConstraintProgramScheduleBuilder - Interface in io.cdap.cdap.api.schedule
-
Similar to
ScheduleBuilder
, but allows specifying whether the scheduler should wait until the
configured constraint is met.
- constructor(Constructor<?>) - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Returns the
Invokable
for
constructor
, which must be a member of
T
.
- ConsumablePartition - Interface in io.cdap.cdap.api.dataset.lib.partitioned
-
Represents a
Partition
available for consuming.
- consumePartitions() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.AbstractPartitionConsumer
-
- consumePartitions(int) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.AbstractPartitionConsumer
-
- consumePartitions(PartitionAcceptor) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.AbstractPartitionConsumer
-
- consumePartitions() - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.PartitionConsumer
-
- consumePartitions(int) - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.PartitionConsumer
-
- consumePartitions(PartitionAcceptor) - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.PartitionConsumer
-
- consumePartitions() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.TransactionalPartitionConsumer
-
- consumePartitions(int) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.TransactionalPartitionConsumer
-
- consumePartitions(PartitionAcceptor) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.TransactionalPartitionConsumer
-
- consumePartitions(PartitionConsumerState) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Incrementally consumes partitions.
- consumePartitions(PartitionConsumerState, int, Predicate<PartitionDetail>) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Incrementally consumes partitions.
- ConsumerConfiguration - Class in io.cdap.cdap.api.dataset.lib.partitioned
-
- ConsumerConfiguration.Builder - Class in io.cdap.cdap.api.dataset.lib.partitioned
-
A Builder to construct ConsumerConfiguration instances.
- ConsumerWorkingSet - Class in io.cdap.cdap.api.dataset.lib.partitioned
-
Keeps track of a list of partitions that are either available for consuming or are currently being consumed.
- ConsumerWorkingSet() - Constructor for class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerWorkingSet
-
Constructs an empty working set.
- containsKey(String) - Method in class io.cdap.cdap.api.metadata.MetadataEntity
-
- containsMacro(String) - Method in class io.cdap.cdap.api.plugin.PluginConfig
-
Returns true if property value contains a macro; false otherwise.
- convertKey(FROM_KEY) - Method in class io.cdap.cdap.api.data.batch.SplitReaderAdapter
-
- convertValue(FROM_VALUE) - Method in class io.cdap.cdap.api.data.batch.SplitReaderAdapter
-
- count(String, int) - Method in interface io.cdap.cdap.api.metrics.Metrics
-
Increases the value of the specific metric by delta.
- CounterTimeseriesTable - Class in io.cdap.cdap.api.dataset.lib
-
A Dataset for incrementing counts over time periods.
- CounterTimeseriesTable(DatasetSpecification, Table) - Constructor for class io.cdap.cdap.api.dataset.lib.CounterTimeseriesTable
-
Creates an instance of the DataSet.
- CounterTimeseriesTable.Counter - Class in io.cdap.cdap.api.dataset.lib
-
- CounterTimeseriesTableDefinition - Class in io.cdap.cdap.api.dataset.lib
-
- CounterTimeseriesTableDefinition(String, DatasetDefinition<? extends Table, ?>) - Constructor for class io.cdap.cdap.api.dataset.lib.CounterTimeseriesTableDefinition
-
- countLong(String, long) - Method in interface io.cdap.cdap.api.metrics.Metrics
-
Increases the value of the specific metric by delta.
- create() - Method in interface io.cdap.cdap.api.dataset.DatasetAdmin
-
Creates dataset.
- create() - Method in class io.cdap.cdap.api.dataset.lib.CompositeDatasetAdmin
-
- createClassLoader(ArtifactInfo, ClassLoader) - Method in interface io.cdap.cdap.api.artifact.ArtifactManager
-
Create a class loader using the artifact represented by artifactInfo with parent as parentClassloader
Call to this method might take a long time based on the size of the artifact.
- createClassLoader(String, ArtifactInfo, ClassLoader) - Method in interface io.cdap.cdap.api.artifact.ArtifactManager
-
Create a class loader using the artifact represented by artifactInfo with parent as parentClassloader
Call to this method might take a long time based on the size of the artifact.
- createClassLoader() - Method in interface io.cdap.cdap.api.service.http.ServicePluginConfigurer
-
Creates a new instance of
ClassLoader
that contains this program classloader, all the plugins
export-package classloader instantiated by this configurer and system classloader in that loading order.
- createDataset(String, String, DatasetProperties) - Method in interface io.cdap.cdap.api.dataset.DatasetManager
-
Create a new dataset instance.
- createDataset(String, String, DatasetProperties) - Method in interface io.cdap.cdap.api.DatasetConfigurer
-
Adds a Dataset instance, created automatically if absent in the CDAP namespace.
- createDataset(String, String) - Method in interface io.cdap.cdap.api.DatasetConfigurer
-
- createDataset(String, Class<? extends Dataset>, DatasetProperties) - Method in interface io.cdap.cdap.api.DatasetConfigurer
-
Deploys a Dataset type using the datasetClass parameter (see
DatasetConfigurer.addDatasetType(Class)
), then
adds a Dataset instance, if absent in the CDAP namespace, or if the Dataset instance already exists,
updates the existing instance with the new properties.
- createDataset(String, Class<? extends Dataset>) - Method in interface io.cdap.cdap.api.DatasetConfigurer
-
Deploys a Dataset type using the datasetClass parameter (see
DatasetConfigurer.addDatasetType(Class)
), then
adds a Dataset instance, if absent in the CDAP namespace, or if the Dataset instance already exists,
updates the existing instance with empty properties.
- createDataset(String, String) - Method in class io.cdap.cdap.internal.api.AbstractProgramDatasetConfigurable
-
- createDataset(String, String, DatasetProperties) - Method in class io.cdap.cdap.internal.api.AbstractProgramDatasetConfigurable
-
- createDataset(String, Class<? extends Dataset>, DatasetProperties) - Method in class io.cdap.cdap.internal.api.AbstractProgramDatasetConfigurable
-
- createDataset(String, Class<? extends Dataset>) - Method in class io.cdap.cdap.internal.api.AbstractProgramDatasetConfigurable
-
- createDataset(String, String, DatasetProperties) - Method in class io.cdap.cdap.internal.api.DefaultDatasetConfigurer
-
- createDataset(String, String) - Method in class io.cdap.cdap.internal.api.DefaultDatasetConfigurer
-
- createDataset(String, Class<? extends Dataset>, DatasetProperties) - Method in class io.cdap.cdap.internal.api.DefaultDatasetConfigurer
-
- createDataset(String, Class<? extends Dataset>) - Method in class io.cdap.cdap.internal.api.DefaultDatasetConfigurer
-
- createIndexedObjectStore(ApplicationConfigurer, String, Type, DatasetProperties) - Static method in class io.cdap.cdap.api.dataset.lib.ObjectStores
-
- createIndexedObjectStore(ApplicationConfigurer, String, Type) - Static method in class io.cdap.cdap.api.dataset.lib.ObjectStores
-
- createIterator(Split) - Method in class io.cdap.cdap.api.data.batch.IteratorBasedSplitReader
-
Creates an iterator to iterate through all records of a given split.
- createIterator(Split) - Method in class io.cdap.cdap.api.dataset.lib.TimeseriesTable.TimeseriesTableRecordsReader
-
- createLocalDataset(String, String, DatasetProperties) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
Adds a local dataset instance to the
Workflow
.
- createLocalDataset(String, String) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- createLocalDataset(String, Class<? extends Dataset>, DatasetProperties) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
Adds a local dataset instance to the
Workflow
.
- createLocalDataset(String, Class<? extends Dataset>) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- createLocalDataset(String, String, DatasetProperties) - Method in interface io.cdap.cdap.api.workflow.WorkflowConfigurer
-
Adds a local dataset instance to the
Workflow
.
- createLocalDataset(String, Class<? extends Dataset>, DatasetProperties) - Method in interface io.cdap.cdap.api.workflow.WorkflowConfigurer
-
Adds a local dataset instance to the
Workflow
.
- createObjectStore(ApplicationConfigurer, String, Type, DatasetProperties) - Static method in class io.cdap.cdap.api.dataset.lib.ObjectStores
-
Adds an
ObjectStore
dataset to be created at application deploy if it does not exist.
- createObjectStore(ApplicationConfigurer, String, Type) - Static method in class io.cdap.cdap.api.dataset.lib.ObjectStores
-
- createPluginConfigurer() - Method in interface io.cdap.cdap.api.service.http.HttpServiceContext
-
- createPluginConfigurer(String) - Method in interface io.cdap.cdap.api.service.http.HttpServiceContext
-
- createServicePluginConfigurer() - Method in interface io.cdap.cdap.api.service.http.HttpServiceContext
-
Create a
ServicePluginConfigurer
that can be used to instantiate plugins at runtime that
were not registered at configure time.
- createServicePluginConfigurer(String) - Method in interface io.cdap.cdap.api.service.http.HttpServiceContext
-
Create a
ServicePluginConfigurer
that can be used to instantiate plugins at runtime that
were not registered at configure time.
- createSplitReader(Split) - Method in interface io.cdap.cdap.api.data.batch.BatchReadable
-
Creates a reader for the split of a dataset.
- createSplitReader(Split) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- createSplitReader(Split) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
- createSplitReader(Split) - Method in class io.cdap.cdap.api.dataset.lib.TimeseriesTable
-
- createSplitRecordScanner(Split) - Method in interface io.cdap.cdap.api.data.batch.RecordScannable
-
Creates a reader for the split of a dataset.
- createSplitRecordScanner(Split) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- createSplitRecordScanner(Split) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
- createTable(ApplicationConfigurer, String, int) - Static method in class io.cdap.cdap.api.dataset.lib.TimeseriesTables
-
Adds
TimeseriesTable
data set to be created at application deploy if not exists.
- createTable(ApplicationConfigurer, String) - Static method in class io.cdap.cdap.api.dataset.table.Tables
-
Adds
Table
data set to be created at application deploy if not exists.
- createTable(ApplicationConfigurer, String, int) - Static method in class io.cdap.cdap.api.dataset.table.Tables
-
Adds
Table
data set to be created at application deploy if not exists.
- createTable(ApplicationConfigurer, String, ConflictDetection) - Static method in class io.cdap.cdap.api.dataset.table.Tables
-
Adds
Table
data set to be created at application deploy if not exists.
- createTable(ApplicationConfigurer, String, ConflictDetection, int) - Static method in class io.cdap.cdap.api.dataset.table.Tables
-
Adds
Table
data set to be created at application deploy if not exists.
- createTable(ApplicationConfigurer, String, ConflictDetection, int, DatasetProperties) - Static method in class io.cdap.cdap.api.dataset.table.Tables
-
Adds
Table
data set to be created at application deploy if not exists.
- createTopic(String) - Method in interface io.cdap.cdap.api.messaging.MessagingAdmin
-
Creates a new topic with the default topic properties.
- createTopic(String, Map<String, String>) - Method in interface io.cdap.cdap.api.messaging.MessagingAdmin
-
Creates a new topic.
- Creator<T> - Interface in io.cdap.cdap.api.builder
-
- Cube - Interface in io.cdap.cdap.api.dataset.lib.cube
-
Cube data set.
- CubeDeleteQuery - Class in io.cdap.cdap.api.dataset.lib.cube
-
Defines a query for deleting data in
Cube
.
- CubeDeleteQuery(long, long, int, Map<String, String>, Collection<String>, Predicate<List<String>>) - Constructor for class io.cdap.cdap.api.dataset.lib.cube.CubeDeleteQuery
-
- CubeExploreQuery - Class in io.cdap.cdap.api.dataset.lib.cube
-
Defines a query to perform exploration of the
Cube
data, e.g.
- CubeExploreQuery(long, long, int, int, List<DimensionValue>) - Constructor for class io.cdap.cdap.api.dataset.lib.cube.CubeExploreQuery
-
- CubeExploreQuery.Builder - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeExploreQuery.Builder.Build - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeExploreQuery.Builder.Dimension - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeExploreQuery.Builder.From - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeExploreQuery.Builder.Limit - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeExploreQuery.Builder.Where - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeFact - Class in io.cdap.cdap.api.dataset.lib.cube
-
Time-based measurement with associated dimensionValues (dimensions) to be stored in
Cube
.
- CubeFact(long) - Constructor for class io.cdap.cdap.api.dataset.lib.cube.CubeFact
-
Creates an instance of
CubeFact
with no dimensionValues and no measurements.
- CubeQuery - Class in io.cdap.cdap.api.dataset.lib.cube
-
Defines a query to perform on
Cube
data.
- CubeQuery(String, long, long, int, int, Map<String, AggregationFunction>, Map<String, String>, List<String>, AggregationOption, Interpolator) - Constructor for class io.cdap.cdap.api.dataset.lib.cube.CubeQuery
-
- CubeQuery.Builder - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeQuery.Builder.Build - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeQuery.Builder.Dimension - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeQuery.Builder.From - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeQuery.Builder.GroupBy - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeQuery.Builder.GroupByDimension - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeQuery.Builder.Limit - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeQuery.Builder.Measurement - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeQuery.Builder.Select - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CubeQuery.Builder.Where - Class in io.cdap.cdap.api.dataset.lib.cube
-
- CustomAction - Interface in io.cdap.cdap.api.customaction
-
Defines custom action in the Workflow.
- CustomActionConfigurer - Interface in io.cdap.cdap.api.customaction
-
- CustomActionContext - Interface in io.cdap.cdap.api.customaction
-
Represents runtime context of the
CustomAction
in the Workflow.
- CustomActionSpecification - Interface in io.cdap.cdap.api.customaction
-
Specification for the custom java code that will be executed as a part of
Workflow
.
- DATA_EXTERNAL - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
Whether the files in the dataset are "external", that is, managed by an external process.
- DATA_POSSESS_EXISTING - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
If true, the file set will use an existing directory as its base path and an existing Explore table,
and it will take possession of them.
- DATA_USE_EXISTING - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
If true, the file set will use an existing directory as its base path and an existing Explore table.
- Dataset - Interface in io.cdap.cdap.api.dataset
-
Implementations of this class perform data operations on dataset instance.
- DATASET - Static variable in class io.cdap.cdap.api.metadata.MetadataEntity
-
- DatasetAdmin - Interface in io.cdap.cdap.api.dataset
-
Defines the minimum administrative operations a dataset should support.
- DatasetConfigurer - Interface in io.cdap.cdap.api
-
Provides the ability to add datasets.
- DatasetContext - Interface in io.cdap.cdap.api.data
-
This interface provides methods that instantiate or dismiss a Dataset during the runtime
of a program.
- DatasetContext - Class in io.cdap.cdap.api.dataset
-
Provides access to the context for a dataset including its environment and configuration
- DatasetCreationSpec - Class in io.cdap.cdap.internal.dataset
-
Information for creating dataset instance.
- DatasetCreationSpec(String, String, DatasetProperties) - Constructor for class io.cdap.cdap.internal.dataset.DatasetCreationSpec
-
- DatasetDefinition<D extends Dataset,A extends DatasetAdmin> - Interface in io.cdap.cdap.api.dataset
-
Defines named dataset type implementation.
- DatasetDefinitionRegistry - Interface in io.cdap.cdap.api.dataset.module
-
Registry of dataset definitions and other components in a Datasets System.
- DataSetException - Exception in io.cdap.cdap.api.dataset
-
Thrown when a data operation fails.
- DataSetException(String) - Constructor for exception io.cdap.cdap.api.dataset.DataSetException
-
- DataSetException(String, Throwable) - Constructor for exception io.cdap.cdap.api.dataset.DataSetException
-
- DataSetException(Throwable) - Constructor for exception io.cdap.cdap.api.dataset.DataSetException
-
- datasetExists(String) - Method in interface io.cdap.cdap.api.dataset.DatasetManager
-
Check whether a dataset exists in the current namespace.
- DataSetFieldExtractor - Class in io.cdap.cdap.internal.specification
-
- DataSetFieldExtractor(Set<String>) - Constructor for class io.cdap.cdap.internal.specification.DataSetFieldExtractor
-
- DatasetInstantiationException - Exception in io.cdap.cdap.api.data
-
This exception is thrown if - for whatever reason - a data set cannot be
instantiated at runtime.
- DatasetInstantiationException(String, Throwable) - Constructor for exception io.cdap.cdap.api.data.DatasetInstantiationException
-
- DatasetInstantiationException(String) - Constructor for exception io.cdap.cdap.api.data.DatasetInstantiationException
-
- DatasetManagementException - Exception in io.cdap.cdap.api.dataset
-
Thrown when there's an error during dataset modules, types or instances management operations.
- DatasetManagementException(String) - Constructor for exception io.cdap.cdap.api.dataset.DatasetManagementException
-
- DatasetManagementException(String, Throwable) - Constructor for exception io.cdap.cdap.api.dataset.DatasetManagementException
-
- DatasetManager - Interface in io.cdap.cdap.api.dataset
-
Provides dataset management functions.
- DatasetModule - Interface in io.cdap.cdap.api.dataset.module
-
Implementation of
DatasetModule
announces dataset types and other components to the system.
- DatasetOutputCommitter - Interface in io.cdap.cdap.api.data.batch
-
This interface is implemented by a dataset if at the end of a batch job (MapReduce, Spark, ...)
the output needs to be committed, or rolled back, depending on success of the job.
- DatasetProperties - Class in io.cdap.cdap.api.dataset
-
Dataset instance properties.
- DatasetProperties.Builder - Class in io.cdap.cdap.api.dataset
-
A Builder to construct DatasetProperties instances.
- DatasetRuntimeContext - Class in io.cdap.cdap.internal.dataset
-
The internal context object used by the Dataset framework to track Dataset methods.
- DatasetRuntimeContext() - Constructor for class io.cdap.cdap.internal.dataset.DatasetRuntimeContext
-
- datasets(DatasetSpecification...) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification.Builder
-
Add underlying dataset specs.
- datasets(Collection<? extends DatasetSpecification>) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification.Builder
-
Add underlying dataset specs.
- DatasetSpecification - Class in io.cdap.cdap.api.dataset
-
A
DatasetSpecification
is a hierarchical meta data object that contains all
meta data needed to instantiate a dataset at runtime.
- DatasetSpecification.Builder - Class in io.cdap.cdap.api.dataset
-
A Builder to construct DatasetSpecification instances.
- DatasetStatePersistor - Interface in io.cdap.cdap.api.dataset.lib
-
Defines how some state will be persisted/managed, using a
DatasetContext
to read and persist state.
- DatasetType - Annotation Type in io.cdap.cdap.api.dataset.module
-
Annotation to declare a dataset type from
Dataset
.
- DataTracer - Interface in io.cdap.cdap.api.preview
-
Interface used by the CDAP applications to trace the data.
- decode(String, T, ClassLoader) - Static method in class io.cdap.cdap.api.data.batch.Splits
-
- decodePayload(Function<Reader, T>) - Method in interface io.cdap.cdap.api.messaging.Message
-
Decodes the message payload.
- DEFAULT - Static variable in class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerConfiguration
-
Instance of ConsumerConfiguration with default parameters
- DEFAULT - Static variable in class io.cdap.cdap.api.macro.MacroParserOptions
-
- DEFAULT_COLUMN_FAMILY - Static variable in interface io.cdap.cdap.api.dataset.table.Table
-
The default column family.
- DEFAULT_MAX_ALLOWED_GAP - Static variable in class io.cdap.cdap.api.dataset.lib.cube.Interpolators
-
- DEFAULT_TYPE - Static variable in annotation type io.cdap.cdap.api.annotation.Plugin
-
Default plugin type name.
- DEFAULT_TYPE_NAME - Static variable in annotation type io.cdap.cdap.api.dataset.module.EmbeddedDataset
-
- DefaultConditionSpecification - Class in io.cdap.cdap.internal.workflow.condition
-
- DefaultConditionSpecification(String, String, String, Map<String, String>, Set<String>) - Constructor for class io.cdap.cdap.internal.workflow.condition.DefaultConditionSpecification
-
- DefaultConsumablePartition - Class in io.cdap.cdap.api.dataset.lib.partitioned
-
- DefaultConsumablePartition(PartitionKey) - Constructor for class io.cdap.cdap.api.dataset.lib.partitioned.DefaultConsumablePartition
-
- DefaultConsumablePartition(PartitionKey, ProcessState, long, int) - Constructor for class io.cdap.cdap.api.dataset.lib.partitioned.DefaultConsumablePartition
-
- DefaultCustomActionSpecification - Class in io.cdap.cdap.internal.customaction
-
- DefaultCustomActionSpecification(String, String, String, Map<String, String>, Set<String>) - Constructor for class io.cdap.cdap.internal.customaction.DefaultCustomActionSpecification
-
- DefaultDatasetConfigurer - Class in io.cdap.cdap.internal.api
-
- DefaultDatasetConfigurer() - Constructor for class io.cdap.cdap.internal.api.DefaultDatasetConfigurer
-
- DefaultTriggeringScheduleInfo - Class in io.cdap.cdap.internal.app.runtime.schedule
-
- DefaultTriggeringScheduleInfo(String, String, List<TriggerInfo>, Map<String, String>) - Constructor for class io.cdap.cdap.internal.app.runtime.schedule.DefaultTriggeringScheduleInfo
-
- delegate() - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken.TypeSet
-
- delegates - Variable in class io.cdap.cdap.api.dataset.lib.CompositeDatasetAdmin
-
- DelegatingStatePersistor - Class in io.cdap.cdap.api.dataset.lib.partitioned
-
- DelegatingStatePersistor(DatasetContext, DatasetStatePersistor) - Constructor for class io.cdap.cdap.api.dataset.lib.partitioned.DelegatingStatePersistor
-
- delete(CubeDeleteQuery) - Method in interface io.cdap.cdap.api.dataset.lib.cube.Cube
-
Deletes the data specified by
CubeQuery
from all the fact tables.
- delete(Delete) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Perform a delete on the data table.
- delete(byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- delete(byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- delete(byte[], byte[][]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- delete(String) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
Delete a key.
- delete(byte[]) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
Delete a key.
- delete(String) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectMappedTable
-
Delete the object for the specified key.
- delete(byte[]) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectMappedTable
-
Delete the object for the specified key.
- delete(byte[]) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectStore
-
Delete the object for the specified key.
- Delete - Class in io.cdap.cdap.api.dataset.table
-
A Delete removes one, multiple, or all columns from a row.
- Delete(byte[]) - Constructor for class io.cdap.cdap.api.dataset.table.Delete
-
Delete whole row.
- Delete(byte[], byte[]...) - Constructor for class io.cdap.cdap.api.dataset.table.Delete
-
Delete a set of columns from a row.
- Delete(byte[], Collection<byte[]>) - Constructor for class io.cdap.cdap.api.dataset.table.Delete
-
Delete a set of columns from a row.
- Delete(String) - Constructor for class io.cdap.cdap.api.dataset.table.Delete
-
Delete a whole row.
- Delete(String, String...) - Constructor for class io.cdap.cdap.api.dataset.table.Delete
-
Delete a set of columns from a row.
- Delete(String, Collection<String>) - Constructor for class io.cdap.cdap.api.dataset.table.Delete
-
Delete a set of columns from a row.
- delete(byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Deletes all columns of the specified row.
- delete(byte[], byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Deletes specified column of the specified row.
- delete(byte[], byte[][]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Deletes specified columns of the specified row.
- delete(Delete) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Deletes columns of a row as defined by the
Delete
parameter.
- delete(String, String) - Method in interface io.cdap.cdap.api.security.store.SecureStoreManager
-
Deletes the element with the given name.
- deleteTopic(String) - Method in interface io.cdap.cdap.api.messaging.MessagingAdmin
-
Deletes a topic.
- Description - Annotation Type in io.cdap.cdap.api.annotation
-
Annotates the description for the element.
- DescriptionSetter<T> - Interface in io.cdap.cdap.api.builder
-
- deserialize(DataInput, ClassLoader) - Static method in class io.cdap.cdap.api.data.batch.Splits
-
- deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class io.cdap.cdap.api.dataset.lib.ConditionCodec
-
- deserialize(JsonElement, Type, JsonDeserializationContext) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.PartitionKeyCodec
-
- deserializeComparable(JsonElement, JsonDeserializationContext) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ComparableCodec
-
- destroy() - Method in class io.cdap.cdap.api.customaction.AbstractCustomAction
-
- destroy() - Method in class io.cdap.cdap.api.dataset.lib.DynamicPartitioner
-
Destroys a DynamicPartitioner.
- destroy() - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
- destroy() - Method in interface io.cdap.cdap.api.ProgramLifecycle
-
Destroy is the last thing that gets called before the program is
shutdown.
- destroy() - Method in class io.cdap.cdap.api.service.http.AbstractHttpServiceHandler
-
- destroy() - Method in interface io.cdap.cdap.api.service.http.HttpServiceHandler
-
Invoked whenever an instance of this HttpServiceHandler is destroyed.
- destroy() - Method in interface io.cdap.cdap.api.service.Service
-
Destroy the Service
.
- destroy() - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
- destroy() - Method in class io.cdap.cdap.api.worker.AbstractWorker
-
By default, this method is a no-op.
- destroy() - Method in interface io.cdap.cdap.api.worker.Worker
-
Destroy the Worker
.
- destroy() - Method in class io.cdap.cdap.api.workflow.AbstractCondition
-
- destroy() - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- dimension(String, String) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeExploreQuery.Builder.Dimension
-
Adds dimension value to filter by.
- dimension(String, String) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery.Builder.Dimension
-
Adds dimension value to filter by.
- dimension(String) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery.Builder.GroupByDimension
-
Adds dimension to use for grouping results into time series.
- dimensions(List<DimensionValue>) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeExploreQuery.Builder.Dimension
-
Adds dimension values to filter by.
- dimensions(Map<String, String>) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery.Builder.Dimension
-
Adds dimension values to filter by.
- dimensions(List<String>) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery.Builder.GroupByDimension
-
Adds dimensions to use for grouping results into time series.
- DimensionValue - Class in io.cdap.cdap.api.dataset.lib.cube
-
Represents dimension and its value associated with
CubeFact
.
- DimensionValue(String, String) - Constructor for class io.cdap.cdap.api.dataset.lib.cube.DimensionValue
-
- disableFunctions() - Method in class io.cdap.cdap.api.macro.MacroParserOptions.Builder
-
- disableLookups() - Method in class io.cdap.cdap.api.macro.MacroParserOptions.Builder
-
- discard() - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.ConsumablePartition
-
Marks the ProcessState as DISCARDED
- discard() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.DefaultConsumablePartition
-
- discardDataset(Dataset) - Method in interface io.cdap.cdap.api.data.DatasetContext
-
Calling this means that the dataset is not used by the caller any more,
and the DatasetContext must close and discard it as soon as possible.
- doConsume(ConsumerWorkingSet, PartitionAcceptor) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.AbstractPartitionConsumer
-
This method will be called whenever a
PartitionConsumer
requests partitions, to consume partitions
from the working set, while marking them as IN_PROGRESS
- doConsume(ConsumerWorkingSet, PartitionAcceptor) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConcurrentPartitionConsumer
-
- doExpiry(ConsumerWorkingSet) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConcurrentPartitionConsumer
-
Goes through all partitions.
- doFinish(ConsumerWorkingSet, List<? extends PartitionKey>, boolean) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.AbstractPartitionConsumer
-
This method will be called on any partitions returned by the #consumePartitions
method.
- doFinish(ConsumerWorkingSet, List<? extends PartitionKey>, boolean) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConcurrentPartitionConsumer
-
- doGenerate(TypeToken<?>, Set<String>, boolean) - Method in class io.cdap.cdap.internal.io.AbstractSchemaGenerator
-
Actual schema generation.
- drop() - Method in interface io.cdap.cdap.api.dataset.DatasetAdmin
-
Drops dataset.
- drop() - Method in class io.cdap.cdap.api.dataset.lib.CompositeDatasetAdmin
-
- dropDataset(String) - Method in interface io.cdap.cdap.api.dataset.DatasetManager
-
Delete a dataset instance.
- dropPartition(PartitionKey) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Remove a partition for a given partition key, silently ignoring if the key is not found.
- dropPartition(long) - Method in interface io.cdap.cdap.api.dataset.lib.TimePartitionedFileSet
-
Remove a partition for a given time.
- DYNAMIC_INDEXING - Static variable in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Configuration that specifies that the index columns will be specified at runtime, rather than at configure time.
- DYNAMIC_INDEXING_PREFIX - Static variable in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Configuration that specifies the prefix to use to distinguish indexed rows of different tables when dynamic
indexing is enabled.
- DYNAMIC_PARTITIONER_ALLOW_CONCURRENCY - Static variable in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
- DYNAMIC_PARTITIONER_CLASS_NAME - Static variable in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
- DYNAMIC_PARTITIONER_WRITE_OPTION - Static variable in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
- DynamicPartitioner<K,V> - Class in io.cdap.cdap.api.dataset.lib
-
Responsible for dynamically determining a @{link PartitionKey}.
- DynamicPartitioner() - Constructor for class io.cdap.cdap.api.dataset.lib.DynamicPartitioner
-
- DynamicPartitioner.PartitionWriteOption - Enum in io.cdap.cdap.api.dataset.lib
-
Defines options for when writing to a partition.
- gauge(String, long) - Method in interface io.cdap.cdap.api.metrics.Metrics
-
Sets the specific metric to the provided value.
- gauge(String, long) - Method in interface io.cdap.cdap.api.metrics.MetricsCollector
-
Gauge a metric value at the current time.
- generate(Type) - Method in class io.cdap.cdap.internal.io.AbstractSchemaGenerator
-
- generate(Type, boolean) - Method in class io.cdap.cdap.internal.io.AbstractSchemaGenerator
-
- generate(Type) - Method in interface io.cdap.cdap.internal.io.SchemaGenerator
-
- generate(Type, boolean) - Method in interface io.cdap.cdap.internal.io.SchemaGenerator
-
- generateRecord(TypeToken<?>, Set<String>, boolean) - Method in class io.cdap.cdap.internal.io.AbstractSchemaGenerator
-
Generates a RECORD schema of the given type.
- generateRecord(TypeToken<?>, Set<String>, boolean) - Method in class io.cdap.cdap.internal.io.ReflectionSchemaGenerator
-
- get(String) - Method in class io.cdap.cdap.api.data.batch.SimpleSplit
-
Gets an attribute value.
- get(String, String) - Method in class io.cdap.cdap.api.data.batch.SimpleSplit
-
Gets an attribute value.
- get(Get) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Read a row by row key from the data table.
- get(byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- get(byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- get(byte[], byte[][]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- get(byte[], byte[], byte[], int) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- get(List<Get>) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- get(String) - Method in class io.cdap.cdap.api.dataset.lib.PartitionMetadata
-
Performs a get on the underlying map of user-defined metadata.
- get(String) - Method in interface io.cdap.cdap.api.dataset.module.DatasetDefinitionRegistry
-
- get(byte[]) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- get(String) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- Get - Class in io.cdap.cdap.api.dataset.table
-
A Get reads one, multiple, or all columns of a row.
- Get(byte[]) - Constructor for class io.cdap.cdap.api.dataset.table.Get
-
Get all of the columns of a row.
- Get(byte[], byte[]...) - Constructor for class io.cdap.cdap.api.dataset.table.Get
-
Get a set of columns of a row.
- Get(byte[], Collection<byte[]>) - Constructor for class io.cdap.cdap.api.dataset.table.Get
-
Get a set of columns of a row.
- Get(String) - Constructor for class io.cdap.cdap.api.dataset.table.Get
-
Get all of the columns of a row.
- Get(String, String...) - Constructor for class io.cdap.cdap.api.dataset.table.Get
-
Get a set of columns of a row.
- Get(String, Collection<String>) - Constructor for class io.cdap.cdap.api.dataset.table.Get
-
Get a set of columns of a row.
- get(byte[]) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- get(String) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- get(byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- get(String) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- get(byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Reads values of all columns of the specified row.
- get(byte[], byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Reads the value of the specified column of the specified row.
- get(byte[], byte[][]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Reads the values of the specified columns of the specified row.
- get(byte[], byte[], byte[], int) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Reads the values of all columns in the specified row that are
between the specified start (inclusive) and stop (exclusive) columns.
- get(Get) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Reads values of columns as defined by
Get
parameter.
- get(List<Get>) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Reads values for the rows and columns defined by the
Get
parameters.
- get(String, String) - Method in interface io.cdap.cdap.api.security.store.SecureStore
-
Returns the data stored in the secure store.
- get() - Method in class io.cdap.cdap.api.security.store.SecureStoreData
-
- get(String) - Method in interface io.cdap.cdap.api.workflow.WorkflowToken
-
- get(String, WorkflowToken.Scope) - Method in interface io.cdap.cdap.api.workflow.WorkflowToken
-
Get the most recent value for the specified key for a given scope.
- get(String, String) - Method in interface io.cdap.cdap.api.workflow.WorkflowToken
-
- get(String, String, WorkflowToken.Scope) - Method in interface io.cdap.cdap.api.workflow.WorkflowToken
-
Get the value set for the specified key by the specified node for a given scope.
- get(Object) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- get(Object) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- getActualNumPartitions() - Method in interface io.cdap.cdap.api.schedule.PartitionTriggerInfo
-
- getActualTypeArguments() - Method in class io.cdap.cdap.internal.io.TypeRepresentation
-
- getAdmin(DatasetContext, DatasetSpecification, ClassLoader) - Method in interface io.cdap.cdap.api.dataset.DatasetDefinition
-
Provides dataset admin to be used to perform administrative operations on the dataset instance defined by passed
DatasetSpecification
.
- getAdmin(DatasetContext, DatasetSpecification, ClassLoader) - Method in class io.cdap.cdap.api.dataset.lib.CompositeDatasetDefinition
-
- getAdmin() - Method in interface io.cdap.cdap.api.RuntimeContext
-
- getAggregation() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery
-
- getAggregationOption() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery
-
- getAlias() - Method in class io.cdap.cdap.api.data.batch.Input
-
- getAlias() - Method in class io.cdap.cdap.api.data.batch.Output
-
- getAll(String) - Method in interface io.cdap.cdap.api.workflow.WorkflowToken
-
- getAll(String, WorkflowToken.Scope) - Method in interface io.cdap.cdap.api.workflow.WorkflowToken
-
Same key can be added to the WorkflowToken by multiple nodes.
- getAll() - Method in interface io.cdap.cdap.api.workflow.WorkflowToken
-
Same key can be added to the WorkflowToken by multiple nodes.
- getAll(WorkflowToken.Scope) - Method in interface io.cdap.cdap.api.workflow.WorkflowToken
-
Same key can be added to the WorkflowToken by multiple nodes.
- getAllFromNode(String) - Method in interface io.cdap.cdap.api.workflow.WorkflowToken
-
- getAllFromNode(String, WorkflowToken.Scope) - Method in interface io.cdap.cdap.api.workflow.WorkflowToken
-
- getAllHeaders() - Method in interface io.cdap.cdap.api.service.http.HttpServiceRequest
-
- getAllLocalFiles() - Method in interface io.cdap.cdap.api.TaskLocalizationContext
-
- getAnnotation(Class<A>) - Method in class io.cdap.cdap.internal.guava.reflect.Parameter
-
- getAnnotations() - Method in class io.cdap.cdap.internal.guava.reflect.Parameter
-
- getAnnotationsByType(Class<A>) - Method in class io.cdap.cdap.internal.guava.reflect.Parameter
-
- getAppCDAPVersion() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getApplicationName() - Method in interface io.cdap.cdap.api.schedule.ProgramStatusTriggerInfo
-
- getApplicationSpecification() - Method in interface io.cdap.cdap.api.RuntimeContext
-
- getApps() - Method in class io.cdap.cdap.api.artifact.ArtifactClasses
-
get set of application classes
- getAppVersion() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getArguments() - Method in class io.cdap.cdap.api.data.batch.Input.DatasetInput
-
- getArguments() - Method in class io.cdap.cdap.api.data.batch.Output.DatasetOutput
-
- getArguments() - Method in class io.cdap.cdap.api.macro.MacroFunction
-
return the list of arguments to the function
- getArtifactId() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getArtifactId() - Method in class io.cdap.cdap.api.plugin.Plugin
-
- getAsBoolean() - Method in class io.cdap.cdap.api.workflow.Value
-
- getAsDouble() - Method in class io.cdap.cdap.api.workflow.Value
-
- getAsInt() - Method in class io.cdap.cdap.api.workflow.Value
-
- getAsLong() - Method in class io.cdap.cdap.api.workflow.Value
-
- getBaseLocation() - Method in interface io.cdap.cdap.api.dataset.lib.FileSet
-
Allows to interact directly with the location of this dataset in the underlying file system.
- getBasePath(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getBoolean(byte[]) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getBoolean(byte[], boolean) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getBoolean(String) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getBoolean(String, boolean) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getBoolean(byte[]) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getBoolean(byte[], boolean) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getBoolean(String) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getBoolean(String, boolean) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getBoolean(byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getBoolean(byte[], boolean) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getBoolean(String) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getBoolean(String, boolean) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getBoolean(Object) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- getBoolean(Object) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- getBranches() - Method in class io.cdap.cdap.api.workflow.WorkflowForkNode
-
- getBuildTime() - Method in class io.cdap.cdap.api.PlatformInfo.Version
-
- getBundle() - Static method in class io.cdap.cdap.internal.UserMessages
-
- getByte(Object) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- getByte(Object) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- getCallerClasses() - Static method in class io.cdap.cdap.internal.lang.CallerClassSecurityManager
-
Returns the current execution stack as an array of classes.
- getCapabilities() - Method in class io.cdap.cdap.api.plugin.Requirements
-
- getCategory() - Method in class io.cdap.cdap.api.plugin.PluginClass
-
Returns the category of the plugin.
- getCategoryName() - Method in enum io.cdap.cdap.api.schedule.Trigger.Type
-
- getCause() - Method in class io.cdap.cdap.api.plugin.InvalidPluginProperty
-
- getChar(Object) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- getChar(Object) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- getChildren() - Method in class io.cdap.cdap.api.plugin.PluginPropertyField
-
Returns the list of configs inside this property, empty if it does not contain any.
- getClasses() - Method in class io.cdap.cdap.api.artifact.ArtifactInfo
-
- getClassName() - Method in class io.cdap.cdap.api.AbstractProgramSpecification
-
- getClassName() - Method in class io.cdap.cdap.api.artifact.ApplicationClass
-
Returns the fully qualified class name of the Application Class.
- getClassName() - Method in interface io.cdap.cdap.api.customaction.CustomActionSpecification
-
- getClassName() - Method in class io.cdap.cdap.api.plugin.PluginClass
-
Returns the fully qualified class name of the plugin.
- getClassName() - Method in interface io.cdap.cdap.api.ProgramSpecification
-
- getClassName() - Method in class io.cdap.cdap.api.spark.SparkHttpServiceHandlerSpecification
-
- getClassName() - Method in interface io.cdap.cdap.api.workflow.ConditionSpecification
-
- getClassName() - Method in class io.cdap.cdap.internal.customaction.DefaultCustomActionSpecification
-
- getClassName() - Method in class io.cdap.cdap.internal.workflow.condition.DefaultConditionSpecification
-
- getClientResources() - Method in class io.cdap.cdap.api.spark.SparkSpecification
-
- getClusterName() - Method in interface io.cdap.cdap.api.RuntimeContext
-
- getColumnFamily(DatasetProperties) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getColumnFamily(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getColumnFamilyBytes(DatasetProperties) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getColumnFamilyBytes(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getColumns() - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getColumns() - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getColumns() - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getColumns() - Method in class io.cdap.cdap.api.dataset.table.RowColumns
-
- getComponentType() - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Returns the array component type if this type represents an array (int[]
, T[]
,
<? extends Map<String, Integer>[]>
etc.), or else null
is returned.
- getCondition(String) - Method in class io.cdap.cdap.api.dataset.lib.PartitionFilter
-
- getConditions() - Method in class io.cdap.cdap.api.dataset.lib.PartitionFilter
-
This should be used for inspection or debugging only.
- getConditionSpecification() - Method in class io.cdap.cdap.api.workflow.WorkflowConditionNode
-
- getConditionSpecification() - Method in interface io.cdap.cdap.api.workflow.WorkflowContext
-
- getConfig() - Method in class io.cdap.cdap.api.app.AbstractApplication
-
Get the configuration object.
- getConfig() - Method in interface io.cdap.cdap.api.app.ApplicationContext
-
Get the configuration object.
- getConfig(Type) - Method in interface io.cdap.cdap.api.app.ApplicationUpdateContext
-
Get the old config as an object of the given type.
- getConfigAsString() - Method in interface io.cdap.cdap.api.app.ApplicationUpdateContext
-
Get the application configuration as json string.
- getConfigFieldName() - Method in class io.cdap.cdap.api.plugin.PluginClass
-
Returns the name of the field that extends from
PluginConfig
in the plugin class.
- getConfigSchema() - Method in class io.cdap.cdap.api.artifact.ApplicationClass
-
Returns the schema of the Application config, or null if the Application does not use config
- getConfiguration() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getConfiguration() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.AbstractPartitionConsumer
-
- getConfigurer() - Method in class io.cdap.cdap.api.app.AbstractApplication
-
- getConfigurer() - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
- getConfigurer() - Method in class io.cdap.cdap.api.service.AbstractService
-
- getConfigurer() - Method in class io.cdap.cdap.api.service.http.AbstractHttpServiceHandler
-
- getConfigurer() - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
- getConfigurer() - Method in class io.cdap.cdap.api.worker.AbstractWorker
-
- getConfigurer() - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- getConfigurer() - Method in class io.cdap.cdap.internal.api.AbstractPluginConfigurable
-
- getConfigurer() - Method in class io.cdap.cdap.internal.api.AbstractProgramDatasetConfigurable
-
- getConflictDetection(DatasetProperties, ConflictDetection) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getConflictDetection(Map<String, String>, ConflictDetection) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getConstraints() - Method in class io.cdap.cdap.internal.schedule.ScheduleCreationSpec
-
- getContent() - Method in interface io.cdap.cdap.api.service.http.HttpServiceRequest
-
- getContentLength() - Method in class io.cdap.cdap.api.service.http.HttpContentProducer
-
Returns the length of the content or -1L
if the length is unknown.
- getContext() - Method in class io.cdap.cdap.api.app.AbstractApplication
-
- getContext() - Method in class io.cdap.cdap.api.customaction.AbstractCustomAction
-
- getContext() - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
- getContext() - Method in class io.cdap.cdap.api.service.AbstractService
-
- getContext() - Method in class io.cdap.cdap.api.service.http.AbstractHttpServiceHandler
-
- getContext() - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
- getContext() - Method in class io.cdap.cdap.api.worker.AbstractWorker
-
- getContext() - Method in class io.cdap.cdap.api.workflow.AbstractCondition
-
- getContext() - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- getContext() - Static method in class io.cdap.cdap.internal.dataset.DatasetRuntimeContext
-
- getCounter() - Method in class io.cdap.cdap.api.dataset.lib.CounterTimeseriesTable.Counter
-
Returns the name of the counter.
- getCreationTime() - Method in class io.cdap.cdap.api.dataset.lib.PartitionMetadata
-
- getCronExpression() - Method in interface io.cdap.cdap.api.schedule.TimeTriggerInfo
-
- getCube() - Method in class io.cdap.cdap.api.dataset.lib.cube.AbstractCubeHttpHandler
-
- getCurrentKey() - Method in class io.cdap.cdap.api.data.batch.SplitReader
-
Get the current key.
- getCurrentKey() - Method in class io.cdap.cdap.api.data.batch.SplitReaderAdapter
-
- getCurrentKey() - Method in class io.cdap.cdap.api.data.batch.SplitReaderBase
-
- getCurrentKey() - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable.KeyValueScanner
-
- getCurrentRecord() - Method in class io.cdap.cdap.api.data.batch.RecordScanner
-
Get the current record.
- getCurrentValue() - Method in class io.cdap.cdap.api.data.batch.SplitReader
-
Get the current value.
- getCurrentValue() - Method in class io.cdap.cdap.api.data.batch.SplitReaderAdapter
-
- getCurrentValue() - Method in class io.cdap.cdap.api.data.batch.SplitReaderBase
-
- getCurrentValue() - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable.KeyValueScanner
-
- getCustomActionSpecification() - Method in class io.cdap.cdap.api.workflow.WorkflowActionNode
-
- getDataset(String) - Method in interface io.cdap.cdap.api.data.DatasetContext
-
Get an instance of the specified Dataset.
- getDataset(String, String) - Method in interface io.cdap.cdap.api.data.DatasetContext
-
Get an instance of the specified Dataset.
- getDataset(String, Map<String, String>) - Method in interface io.cdap.cdap.api.data.DatasetContext
-
Get an instance of the specified Dataset.
- getDataset(String, String, Map<String, String>) - Method in interface io.cdap.cdap.api.data.DatasetContext
-
Get an instance of the specified Dataset.
- getDataset(DatasetContext, DatasetSpecification, Map<String, String>, ClassLoader) - Method in interface io.cdap.cdap.api.dataset.DatasetDefinition
-
Provides dataset to be used to perform data operations on the dataset instance data defined by passed
DatasetSpecification
and the given arguments.
- getDataset(DatasetContext, String, DatasetSpecification, Map<String, String>, ClassLoader) - Method in class io.cdap.cdap.api.dataset.lib.CompositeDatasetDefinition
-
Gets a
Dataset
instance from the delegates with the given instance name.
- getDataset(DatasetContext, DatasetSpecification, Map<String, String>, ClassLoader) - Method in class io.cdap.cdap.api.dataset.lib.CounterTimeseriesTableDefinition
-
- getDataset(DatasetContext, DatasetSpecification, Map<String, String>, ClassLoader) - Method in class io.cdap.cdap.api.dataset.lib.IndexedObjectStoreDefinition
-
- getDataset(DatasetContext, DatasetSpecification, Map<String, String>, ClassLoader) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTableDefinition
-
- getDataset(DatasetContext, DatasetSpecification, Map<String, String>, ClassLoader) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTableDefinition
-
- getDataset(DatasetContext, DatasetSpecification, Map<String, String>, ClassLoader) - Method in class io.cdap.cdap.api.dataset.lib.TimeseriesTableDefinition
-
- getDatasetModules() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getDatasetModules() - Method in class io.cdap.cdap.internal.api.DefaultDatasetConfigurer
-
- getDatasetName() - Method in interface io.cdap.cdap.api.schedule.PartitionTriggerInfo
-
- getDatasetNamespace() - Method in interface io.cdap.cdap.api.schedule.PartitionTriggerInfo
-
- getDatasetProperties(String) - Method in interface io.cdap.cdap.api.dataset.DatasetManager
-
Get the properties with which a dataset was created or updated.
- getDatasets() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getDatasets() - Method in interface io.cdap.cdap.api.customaction.CustomActionSpecification
-
- getDataSets() - Method in class io.cdap.cdap.api.mapreduce.MapReduceSpecification
-
- getDatasets() - Method in class io.cdap.cdap.api.service.http.HttpServiceHandlerSpecification
-
- getDatasets() - Method in class io.cdap.cdap.api.spark.SparkHttpServiceHandlerSpecification
-
- getDatasets() - Method in class io.cdap.cdap.api.spark.SparkSpecification
-
Returns the set of static datasets used by the Spark program.
- getDatasets() - Method in class io.cdap.cdap.api.worker.WorkerSpecification
-
- getDatasets() - Method in interface io.cdap.cdap.api.workflow.ConditionSpecification
-
- getDatasets() - Method in class io.cdap.cdap.internal.customaction.DefaultCustomActionSpecification
-
- getDatasets() - Method in class io.cdap.cdap.internal.workflow.condition.DefaultConditionSpecification
-
- getDatasetSpecs() - Method in class io.cdap.cdap.internal.api.DefaultDatasetConfigurer
-
- getDatasetType(String) - Method in interface io.cdap.cdap.api.dataset.DatasetManager
-
Get the type of a dataset.
- getDatasetTypes() - Method in class io.cdap.cdap.api.plugin.Requirements
-
- getDataTracer(String) - Method in interface io.cdap.cdap.api.RuntimeContext
-
- getDeclaredAnnotation(Class<A>) - Method in class io.cdap.cdap.internal.guava.reflect.Parameter
-
- getDeclaredAnnotations() - Method in class io.cdap.cdap.internal.guava.reflect.Parameter
-
- getDeclaredAnnotationsByType(Class<A>) - Method in class io.cdap.cdap.internal.guava.reflect.Parameter
-
- getDeclaringClass() - Method in class io.cdap.cdap.internal.guava.reflect.Invokable
-
- getDeclaringInvokable() - Method in class io.cdap.cdap.internal.guava.reflect.Parameter
-
Returns the
Invokable
that declares this parameter.
- getDelegate(String) - Method in class io.cdap.cdap.api.dataset.lib.CompositeDatasetDefinition
-
- getDescription() - Method in class io.cdap.cdap.api.AbstractProgramSpecification
-
- getDescription() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getDescription() - Method in class io.cdap.cdap.api.artifact.ApplicationClass
-
Returns description of the Application Class.
- getDescription() - Method in interface io.cdap.cdap.api.customaction.CustomActionSpecification
-
- getDescription() - Method in class io.cdap.cdap.api.dataset.DatasetProperties
-
- getDescription() - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
Returns the description of dataset.
- getDescription() - Method in class io.cdap.cdap.api.lineage.field.Operation
-
- getDescription() - Method in class io.cdap.cdap.api.metadata.MetadataEntity
-
- getDescription() - Method in class io.cdap.cdap.api.NamespaceSummary
-
- getDescription() - Method in class io.cdap.cdap.api.plugin.PluginClass
-
Returns description of the plugin.
- getDescription() - Method in class io.cdap.cdap.api.plugin.PluginPropertyField
-
Returns description for the property.
- getDescription() - Method in interface io.cdap.cdap.api.ProgramSpecification
-
- getDescription() - Method in interface io.cdap.cdap.api.schedule.TriggeringScheduleInfo
-
- getDescription() - Method in class io.cdap.cdap.api.security.store.SecureStoreMetadata
-
- getDescription() - Method in interface io.cdap.cdap.api.workflow.ConditionSpecification
-
- getDescription() - Method in class io.cdap.cdap.internal.app.runtime.schedule.DefaultTriggeringScheduleInfo
-
- getDescription() - Method in class io.cdap.cdap.internal.customaction.DefaultCustomActionSpecification
-
- getDescription() - Method in class io.cdap.cdap.internal.schedule.ScheduleCreationSpec
-
- getDescription() - Method in class io.cdap.cdap.internal.workflow.condition.DefaultConditionSpecification
-
- getDestination() - Method in class io.cdap.cdap.api.lineage.field.WriteOperation
-
- getDimensionValues() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeDeleteQuery
-
- getDimensionValues() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeExploreQuery
-
- getDimensionValues() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeFact
-
- getDimensionValues() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery
-
- getDimensionValues() - Method in class io.cdap.cdap.api.dataset.lib.cube.TimeSeries
-
- getDirectMessagePublisher() - Method in interface io.cdap.cdap.api.messaging.MessagingContext
-
Returns an instance of
MessagePublisher
for publishing messages without a transaction.
- getDouble(byte[]) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getDouble(byte[], double) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getDouble(String) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getDouble(String, double) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getDouble(byte[]) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getDouble(byte[], double) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getDouble(String) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getDouble(String, double) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getDouble(byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getDouble(byte[], double) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getDouble(String) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getDouble(String, double) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getDouble(Object) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- getDouble(Object) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- getDriverResources() - Method in class io.cdap.cdap.api.mapreduce.MapReduceSpecification
-
- getDriverResources() - Method in class io.cdap.cdap.api.spark.SparkSpecification
-
- getDynamicPartitioner(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Return the DynamicPartitioner class that was previously assigned onto runtime arguments.
- getDynamicPartitionerWriteOption(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Return the DynamicPartitioner.PartitionWriteOption class that was previously assigned onto runtime arguments.
- getElseBranch() - Method in class io.cdap.cdap.api.workflow.WorkflowConditionNode
-
- getEmbeddedFileSet() - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
- getEndpoints() - Method in class io.cdap.cdap.api.service.http.HttpServiceHandlerSpecification
-
- getEndpoints() - Method in class io.cdap.cdap.api.spark.SparkHttpServiceHandlerSpecification
-
- getEndTs() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeDeleteQuery
-
- getEndTs() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeExploreQuery
-
- getEndTs() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery
-
- getErrorMessage() - Method in class io.cdap.cdap.api.plugin.InvalidPluginProperty
-
- getException() - Method in interface io.cdap.cdap.api.metrics.RuntimeMetrics
-
- getExceptionTypes() - Method in class io.cdap.cdap.internal.guava.reflect.Invokable
-
Returns all declared exception types of this Invokable
.
- getExecutorResources() - Method in class io.cdap.cdap.api.spark.SparkSpecification
-
- getExpectedNumPartitions() - Method in interface io.cdap.cdap.api.schedule.PartitionTriggerInfo
-
- getExpiryBorder() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConcurrentPartitionConsumer
-
- getExploreDatabaseName(DatasetProperties) - Static method in class io.cdap.cdap.api.dataset.ExploreProperties
-
- getExploreDatabaseName(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.ExploreProperties
-
- getExploreFormat(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getExploreFormatProperties(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getExploreInputFormat(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getExploreOutputFormat(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getExploreSchema(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getExploreTableName(DatasetProperties) - Static method in class io.cdap.cdap.api.dataset.ExploreProperties
-
- getExploreTableName(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.ExploreProperties
-
- getFailedPartitions() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.PartitionConsumerResult
-
- getFailureCause() - Method in class io.cdap.cdap.api.workflow.WorkflowNodeState
-
Return the detail message string for failure if node execution failed, otherwise null
is returned.
- getFailureInfo() - Method in class io.cdap.cdap.api.ProgramState
-
Return any available information on the reason of failure of the program.
- getField(String) - Method in class io.cdap.cdap.api.dataset.lib.PartitionKey
-
- getFieldLineageOperations() - Method in class io.cdap.cdap.api.workflow.WorkflowNodeState
-
Return the field operations recorded by this node.
- getFieldName() - Method in class io.cdap.cdap.api.dataset.lib.PartitionFilter.Condition
-
- getFields() - Method in class io.cdap.cdap.api.dataset.lib.Partitioning
-
This returns a map associating all the fields of this partitioning with their respective types.
- getFields() - Method in class io.cdap.cdap.api.dataset.lib.PartitionKey
-
- getFieldType(String) - Method in class io.cdap.cdap.api.dataset.lib.Partitioning
-
- getFileGroup(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getFilePermissions(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getFilter() - Method in class io.cdap.cdap.api.dataset.table.Scan
-
- getFix() - Method in class io.cdap.cdap.api.artifact.ArtifactVersion
-
get the fix version of artifact
- getFix() - Method in class io.cdap.cdap.api.PlatformInfo.Version
-
- getFloat(byte[]) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getFloat(byte[], float) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getFloat(String) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getFloat(String, float) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getFloat(byte[]) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getFloat(byte[], float) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getFloat(String) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getFloat(String, float) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getFloat(byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getFloat(byte[], float) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getFloat(String) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getFloat(String, float) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getFloat(Object) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- getFloat(Object) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- getFunctionName() - Method in class io.cdap.cdap.api.macro.MacroFunction
-
return the function name
- getFunctionWhitelist() - Method in class io.cdap.cdap.api.macro.MacroParserOptions
-
- getGeneration() - Method in class io.cdap.cdap.api.NamespaceSummary
-
Get the namespace generation.
- getGroupByDimensions() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery
-
- getHadoopContext() - Method in interface io.cdap.cdap.api.mapreduce.MapReduceTaskContext
-
Returns the Hadoop context object for the task.
- getHadoopJob() - Method in interface io.cdap.cdap.api.mapreduce.MapReduceContext
-
Returns the actual Hadoop job.
- getHandlers() - Method in class io.cdap.cdap.api.service.ServiceSpecification
-
Returns an immutable map from handler name to handler specification.
- getHandlers() - Method in class io.cdap.cdap.api.spark.SparkSpecification
-
- getHeader(String) - Method in interface io.cdap.cdap.api.service.http.HttpServiceRequest
-
- getHeaders(String) - Method in interface io.cdap.cdap.api.service.http.HttpServiceRequest
-
Returns all of the values for a specified header
- getId() - Method in interface io.cdap.cdap.api.messaging.Message
-
Returns the unique identifier of this message.
- getIfBranch() - Method in class io.cdap.cdap.api.workflow.WorkflowConditionNode
-
- getInput() - Method in interface io.cdap.cdap.api.metrics.RuntimeMetrics
-
- getInputContext() - Method in interface io.cdap.cdap.api.mapreduce.MapReduceTaskContext
-
Returns an
InputContext
of the input configured for this task.
- getInputDataSet() - Method in class io.cdap.cdap.api.mapreduce.MapReduceSpecification
-
- getInputEndTime(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
Get the end (exclusive) of the time range to be read as input.
- getInputFormat(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getInputFormatClassName() - Method in interface io.cdap.cdap.api.data.batch.InputFormatProvider
-
- getInputFormatConfiguration() - Method in interface io.cdap.cdap.api.data.batch.InputFormatProvider
-
- getInputFormatConfiguration(Iterable<? extends Location>) - Method in interface io.cdap.cdap.api.dataset.lib.FileSet
-
- getInputFormatProvider() - Method in class io.cdap.cdap.api.data.batch.Input.InputFormatProviderInput
-
- getInputLocations() - Method in interface io.cdap.cdap.api.dataset.lib.FileSet
-
Allows direct access to files of this dataset in the underlying file system.
- getInputName() - Method in interface io.cdap.cdap.api.data.batch.InputContext
-
Returns the name of the input configured for this task.
- getInputPartitionFilter(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Get the partition filter for the input to be read.
- getInputPartitionKey() - Method in interface io.cdap.cdap.api.data.batch.PartitionedFileSetInputContext
-
Returns the
PartitionKey
of the input configured for this task.
- getInputPartitionKeys() - Method in interface io.cdap.cdap.api.data.batch.PartitionedFileSetInputContext
-
Returns a Set of
PartitionKey
s of the input configured for this task.
- getInputPartitionKeys(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Get the partition keys to be read for the input.
- getInputPaths(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetArguments
-
- getInputProperties(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getInputs() - Method in class io.cdap.cdap.api.lineage.field.TransformOperation
-
- getInputs() - Method in class io.cdap.cdap.api.lineage.field.WriteOperation
-
- getInputSplits(int, byte[], long, long, byte[]...) - Method in class io.cdap.cdap.api.dataset.lib.TimeseriesTable
-
Defines input selection for batch jobs.
- getInputStartTime(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
Get the start (inclusive) of the time range to be read as input.
- getInstanceCount() - Method in interface io.cdap.cdap.api.service.http.HttpServiceContext
-
- getInstanceCount() - Method in interface io.cdap.cdap.api.service.ServiceContext
-
- getInstanceCount() - Method in interface io.cdap.cdap.api.worker.WorkerContext
-
- getInstanceId() - Method in interface io.cdap.cdap.api.service.http.HttpServiceContext
-
- getInstanceId() - Method in interface io.cdap.cdap.api.service.ServiceContext
-
- getInstanceId() - Method in interface io.cdap.cdap.api.worker.WorkerContext
-
- getInstanceName() - Method in class io.cdap.cdap.internal.dataset.DatasetCreationSpec
-
- getInstances() - Method in class io.cdap.cdap.api.service.ServiceSpecification
-
Returns the number of instances for the service handler.
- getInstances() - Method in class io.cdap.cdap.api.worker.WorkerSpecification
-
- getInt(byte[]) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getInt(byte[], int) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getInt(String) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getInt(String, int) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getInt(byte[]) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getInt(byte[], int) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getInt(String) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getInt(String, int) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getInt(byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getInt(byte[], int) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getInt(String) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getInt(String, int) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getInt(Object) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- getInt(Object) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- getInterpolator() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery
-
- getIntProperty(String, int) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
Lookup a custom property of the dataset.
- getInvalidProperties() - Method in exception io.cdap.cdap.api.plugin.InvalidPluginConfigException
-
- getKey(VALUE) - Method in class io.cdap.cdap.api.data.batch.IteratorBasedSplitReader
-
Gets the key belonging to the key/value record provided by the iterator.
- getKey() - Method in class io.cdap.cdap.api.dataset.lib.KeyValue
-
- getKey(TimeseriesTable.Entry) - Method in class io.cdap.cdap.api.dataset.lib.TimeseriesTable.TimeseriesTableRecordsReader
-
- getKey() - Method in class io.cdap.cdap.api.metadata.MetadataEntity.KeyValue
-
- getKeys() - Method in class io.cdap.cdap.api.metadata.MetadataEntity
-
- getLastModifiedTime() - Method in class io.cdap.cdap.api.security.store.SecureStoreMetadata
-
- getLength() - Method in class io.cdap.cdap.api.data.batch.Split
-
By default assume that the size of each split is roughly the same.
- getLimit() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeExploreQuery
-
- getLimit() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery
-
- getLocalDatasetSpecs() - Method in class io.cdap.cdap.api.workflow.WorkflowSpecification
-
Return the map of local dataset names and associated specifications required for dataset instance creation.
- getLocalFile(String) - Method in interface io.cdap.cdap.api.TaskLocalizationContext
-
Returns a
File
representing the path to a localized file localized with the given name.
- getLocation(String) - Method in interface io.cdap.cdap.api.dataset.lib.FileSet
-
Allows direct access to files in this dataset, in the underlying file system.
- getLocation() - Method in interface io.cdap.cdap.api.dataset.lib.Partition
-
- getLogicalStartTime() - Method in interface io.cdap.cdap.api.customaction.CustomActionContext
-
Returns the logical start time of the batch job which triggers this instance of an action.
- getLogicalStartTime() - Method in interface io.cdap.cdap.api.mapreduce.MapReduceContext
-
Returns the logical start time of this MapReduce job.
- getLogicalStartTime() - Method in interface io.cdap.cdap.api.mapreduce.MapReduceTaskContext
-
Returns the logical start time of this MapReduce job.
- getLogicalStartTime() - Method in interface io.cdap.cdap.api.schedule.TimeTriggerInfo
-
Returns the logical start time of the triggered program.
- getLogicalStartTime() - Method in interface io.cdap.cdap.api.spark.SparkClientContext
-
Returns the logical start time of this Spark job.
- getLogicalStartTime() - Method in interface io.cdap.cdap.api.workflow.WorkflowContext
-
- getLong(byte[]) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getLong(byte[], long) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getLong(String) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getLong(String, long) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getLong(byte[]) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getLong(byte[], long) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getLong(String) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getLong(String, long) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getLong(byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getLong(byte[], long) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getLong(String) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getLong(String, long) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getLong(Object) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- getLong(Object) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- getLongProperty(String, long) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
Lookup a custom property of the dataset.
- getLookups() - Method in class io.cdap.cdap.api.macro.Macros
-
- getLower() - Method in class io.cdap.cdap.api.artifact.ArtifactVersionRange
-
lower version of artifact range
- getLower() - Method in class io.cdap.cdap.api.dataset.lib.PartitionFilter.Condition
-
- getMacroFunctions() - Method in class io.cdap.cdap.api.macro.Macros
-
- getMacros() - Method in class io.cdap.cdap.api.plugin.PluginProperties
-
- getMainClassName() - Method in class io.cdap.cdap.api.spark.SparkSpecification
-
Get the main class name for the Spark program.
- getMajor() - Method in class io.cdap.cdap.api.artifact.ArtifactVersion
-
get the major version of artifact
- getMajor() - Method in class io.cdap.cdap.api.PlatformInfo.Version
-
- getMapperResources() - Method in class io.cdap.cdap.api.mapreduce.MapReduceSpecification
-
- getMapReduce() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getMaxAllowedGap() - Method in interface io.cdap.cdap.api.dataset.lib.cube.Interpolator
-
Data points that are more than this many seconds apart will not cause interpolation to occur and will instead
return 0 for any point in between.
- getMaxAllowedGap() - Method in class io.cdap.cdap.api.dataset.lib.cube.Interpolators.BaseInterpolator
-
- getMaximumTracedRecords() - Method in interface io.cdap.cdap.api.preview.DataTracer
-
Returns the maximum number of records that can be traced by the application
- getMaxRecurseDepth() - Method in class io.cdap.cdap.api.macro.MacroParserOptions
-
- getMaxRetries() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerConfiguration
-
- getMaxWorkingSetSize() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerConfiguration
-
- getMeasurements() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeFact
-
- getMeasurements() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery
-
- getMeasureName() - Method in class io.cdap.cdap.api.dataset.lib.cube.TimeSeries
-
- getMeasureNames() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeDeleteQuery
-
- getMemoryMB() - Method in class io.cdap.cdap.api.Resources
-
Returns the memory size in MB.
- getMessage() - Method in interface io.cdap.cdap.api.common.HttpErrorStatusProvider
-
Gives the error message.
- getMessage(String) - Static method in class io.cdap.cdap.internal.UserMessages
-
- getMessageFetcher() - Method in interface io.cdap.cdap.api.messaging.MessagingContext
-
- getMessagePublisher() - Method in interface io.cdap.cdap.api.messaging.MessagingContext
-
- getMetadata() - Method in interface io.cdap.cdap.api.dataset.lib.PartitionDetail
-
Gets the metadata for the partition
- getMetadata(MetadataEntity) - Method in interface io.cdap.cdap.api.metadata.MetadataReader
-
- getMetadata(MetadataScope, MetadataEntity) - Method in interface io.cdap.cdap.api.metadata.MetadataReader
-
- getMetadata() - Method in class io.cdap.cdap.api.security.store.SecureStoreData
-
- getMethod() - Method in interface io.cdap.cdap.api.service.http.HttpServiceRequest
-
- getMethod() - Method in class io.cdap.cdap.api.service.http.ServiceHttpEndpoint
-
- getMetrics() - Method in interface io.cdap.cdap.api.spark.SparkClientContext
-
Returns a
Metrics
which can be used to emit custom metrics.
- getMinor() - Method in class io.cdap.cdap.api.artifact.ArtifactVersion
-
get the minor version of artifact
- getMinor() - Method in class io.cdap.cdap.api.PlatformInfo.Version
-
- getMissingProperties() - Method in exception io.cdap.cdap.api.plugin.InvalidPluginConfigException
-
- getName() - Method in class io.cdap.cdap.api.AbstractProgramSpecification
-
- getName() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getName() - Method in class io.cdap.cdap.api.artifact.ArtifactId
-
get name of the artifact
- getName() - Method in class io.cdap.cdap.api.artifact.ArtifactRange
-
get the name of the artifact
- getName() - Method in class io.cdap.cdap.api.artifact.ArtifactSummary
-
get the name of the artifact
- getName() - Method in interface io.cdap.cdap.api.customaction.CustomActionSpecification
-
- getName() - Method in class io.cdap.cdap.api.data.batch.Input
-
- getName() - Method in class io.cdap.cdap.api.data.batch.Output
-
- getName() - Method in interface io.cdap.cdap.api.dataset.DatasetDefinition
-
- getName() - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
Returns the name of the dataset.
- getName() - Method in class io.cdap.cdap.api.dataset.lib.AbstractDataset
-
- getName() - Method in class io.cdap.cdap.api.dataset.lib.AbstractDatasetDefinition
-
- getName() - Method in class io.cdap.cdap.api.dataset.lib.cube.DimensionValue
-
- getName() - Method in class io.cdap.cdap.api.dataset.lib.cube.Measurement
-
- getName() - Method in class io.cdap.cdap.api.lineage.field.EndPoint
-
- getName() - Method in class io.cdap.cdap.api.lineage.field.InputField
-
- getName() - Method in class io.cdap.cdap.api.lineage.field.Operation
-
- getName() - Method in class io.cdap.cdap.api.NamespaceSummary
-
- getName() - Method in class io.cdap.cdap.api.plugin.InvalidPluginProperty
-
- getName() - Method in class io.cdap.cdap.api.plugin.PluginClass
-
Returns name of the plugin.
- getName() - Method in class io.cdap.cdap.api.plugin.PluginPropertyField
-
Returns name of the property.
- getName() - Method in interface io.cdap.cdap.api.preview.DataTracer
-
Return the name of the tracer instance.
- getName() - Method in interface io.cdap.cdap.api.ProgramSpecification
-
- getName() - Method in interface io.cdap.cdap.api.schedule.TriggeringScheduleInfo
-
- getName() - Method in class io.cdap.cdap.api.security.store.SecureStoreMetadata
-
- getName() - Method in interface io.cdap.cdap.api.workflow.ConditionSpecification
-
- getName() - Method in interface io.cdap.cdap.api.workflow.WorkflowInfo
-
- getName() - Method in class io.cdap.cdap.internal.app.runtime.schedule.DefaultTriggeringScheduleInfo
-
- getName() - Method in class io.cdap.cdap.internal.customaction.DefaultCustomActionSpecification
-
- getName() - Method in class io.cdap.cdap.internal.schedule.ScheduleCreationSpec
-
- getName() - Method in class io.cdap.cdap.internal.workflow.condition.DefaultConditionSpecification
-
- getNamespace() - Method in class io.cdap.cdap.api.artifact.ArtifactRange
-
get the namespace the artifact belongs to
- getNamespace() - Method in class io.cdap.cdap.api.data.batch.Input
-
- getNamespace() - Method in class io.cdap.cdap.api.data.batch.Output
-
- getNamespace() - Method in class io.cdap.cdap.api.lineage.field.EndPoint
-
- getNamespace() - Method in exception io.cdap.cdap.api.messaging.MessagingException
-
- getNamespace() - Method in interface io.cdap.cdap.api.RuntimeContext
-
- getNamespace() - Method in interface io.cdap.cdap.api.schedule.ProgramStatusTriggerInfo
-
- getNamespaceId() - Method in class io.cdap.cdap.api.dataset.DatasetContext
-
Returns the namespace for a dataset
- getNamespaceSummary(String) - Method in interface io.cdap.cdap.api.Admin
-
Get information about the specified namespace.
- getNewConfig() - Method in class io.cdap.cdap.api.app.ApplicationUpdateResult
-
- getNodeId() - Method in interface io.cdap.cdap.api.workflow.WorkflowInfo
-
- getNodeId() - Method in class io.cdap.cdap.api.workflow.WorkflowNode
-
- getNodeId() - Method in class io.cdap.cdap.api.workflow.WorkflowNodeState
-
Return the id of the node for which the state is maintained.
- getNodeIdMap() - Method in class io.cdap.cdap.api.workflow.WorkflowSpecification
-
- getNodeName() - Method in class io.cdap.cdap.api.workflow.NodeValue
-
- getNodes() - Method in class io.cdap.cdap.api.workflow.WorkflowSpecification
-
Return the list of nodes in the
Workflow
.
- getNodeStates() - Method in interface io.cdap.cdap.api.workflow.WorkflowContext
-
- getNodeStatus() - Method in class io.cdap.cdap.api.workflow.WorkflowNodeState
-
Return the status of the node for which the state is maintained.
- getNumFailures() - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.ConsumablePartition
-
- getNumFailures() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.DefaultConsumablePartition
-
- getObjectSchema(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.ObjectMappedTableProperties
-
- getObjectTypeRepresentation(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.ObjectMappedTableProperties
-
- getOrigin() - Method in class io.cdap.cdap.api.lineage.field.InputField
-
- getOriginalProperties() - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
Return the original properties with which the dataset was created/reconfigured.
- getOutputDataSet() - Method in class io.cdap.cdap.api.mapreduce.MapReduceSpecification
-
- getOutputFormat(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getOutputFormatClassName() - Method in interface io.cdap.cdap.api.data.batch.OutputFormatProvider
-
- getOutputFormatConfiguration() - Method in interface io.cdap.cdap.api.data.batch.OutputFormatProvider
-
- getOutputFormatProvider() - Method in class io.cdap.cdap.api.data.batch.Output.OutputFormatProviderOutput
-
- getOutputLocation() - Method in interface io.cdap.cdap.api.dataset.lib.FileSet
-
Allows direct access to files in the output location, in the underlying file system.
- getOutputPartitionKey(Map<String, String>, Partitioning) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
- getOutputPartitionMetadata(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
- getOutputPartitionTime(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
- getOutputPath(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetArguments
-
- getOutputPathFormat(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
This is the file extension for each partition when using TimePartitionedFileSet as an OutputFormatProvider.
- getOutputPathTimeZone(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
This is the time zone used to format the date for the output partition.
- getOutputProperties(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getOutputs() - Method in class io.cdap.cdap.api.lineage.field.ReadOperation
-
Get the list of outputs generated by this read operation
- getOutputs() - Method in class io.cdap.cdap.api.lineage.field.TransformOperation
-
- getOwnerType() - Method in class io.cdap.cdap.internal.guava.reflect.Invokable
-
Returns the type of T
.
- getOwnerType() - Method in class io.cdap.cdap.internal.io.TypeRepresentation
-
- getParameters() - Method in class io.cdap.cdap.internal.guava.reflect.Invokable
-
Returns all declared parameters of this Invokable
.
- getParents() - Method in class io.cdap.cdap.api.artifact.ArtifactInfo
-
- getParents() - Method in class io.cdap.cdap.api.plugin.Plugin
-
- getPartition(PartitionKey) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Return the partition for a specific partition key, or null if key is not found.
- getPartitionByTime(long) - Method in interface io.cdap.cdap.api.dataset.lib.TimePartitionedFileSet
-
Return the partition associated with the given time, rounded to the minute;
or null if no such partition exists.
- getPartitionConsumerState() - Method in class io.cdap.cdap.api.dataset.lib.PartitionConsumerResult
-
- getPartitionedFileSet() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.AbstractPartitionConsumer
-
- getPartitionedFileSetName() - Method in exception io.cdap.cdap.api.dataset.PartitionNotFoundException
-
- getPartitioning() - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Get the partitioning declared for the file set.
- getPartitioning(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetProperties
-
Read the partitioning for a PartitionedFileSet from its properties.
- getPartitionKey(K, V) - Method in class io.cdap.cdap.api.dataset.lib.DynamicPartitioner
-
Determine the PartitionKey for the key-value pair to be written to.
- getPartitionKey() - Method in interface io.cdap.cdap.api.dataset.lib.Partition
-
- getPartitionKey() - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.ConsumablePartition
-
- getPartitionKey() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.DefaultConsumablePartition
-
- getPartitionKey() - Method in exception io.cdap.cdap.api.dataset.PartitionNotFoundException
-
- getPartitionOutput(PartitionKey) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Return a partition output for a specific partition key, in preparation for creating a new partition.
- getPartitionOutput(long) - Method in interface io.cdap.cdap.api.dataset.lib.TimePartitionedFileSet
-
Return a partition output for a specific time, rounded to the minute, in preparation for creating a new partition.
- getPartitionPredicate() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerConfiguration
-
- getPartitions() - Method in class io.cdap.cdap.api.dataset.lib.PartitionConsumerResult
-
- getPartitions() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerWorkingSet
-
- getPartitions() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.PartitionConsumerResult
-
- getPartitions(PartitionFilter) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Return all partitions matching the partition filter.
- getPartitionsByTime(long, long) - Method in interface io.cdap.cdap.api.dataset.lib.TimePartitionedFileSet
-
Return all partitions within the time range given by startTime (inclusive) and endTime (exclusive),
both rounded to the full minute.
- getPath() - Method in class io.cdap.cdap.api.service.http.ServiceHttpEndpoint
-
- getPayload() - Method in interface io.cdap.cdap.api.messaging.Message
-
Returns the message payload.
- getPayloadAsString(Charset) - Method in interface io.cdap.cdap.api.messaging.Message
-
Returns the message payload as a string decoded with the given
Charset
.
- getPayloadAsString() - Method in interface io.cdap.cdap.api.messaging.Message
-
Returns the message payload as a UTF-8 string.
- getPluginArtifacts(String, String, ArtifactVersionRange) - Method in interface io.cdap.cdap.api.app.ApplicationUpdateContext
-
Returns list of available plugin artifacts based on given parameters.
- getPluginArtifacts(String, String, ArtifactVersionRange, int) - Method in interface io.cdap.cdap.api.app.ApplicationUpdateContext
-
Returns list of available plugin artifacts based on given parameters.
- getPluginClass() - Method in class io.cdap.cdap.api.plugin.Plugin
-
- getPluginProperties(String) - Method in interface io.cdap.cdap.api.plugin.PluginContext
-
- getPluginProperties(String, MacroEvaluator) - Method in interface io.cdap.cdap.api.plugin.PluginContext
-
- getPlugins() - Method in class io.cdap.cdap.api.AbstractProgramSpecification
-
- getPlugins() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getPlugins() - Method in class io.cdap.cdap.api.artifact.ArtifactClasses
-
get the set of plugin classes
- getPlugins() - Method in interface io.cdap.cdap.api.ProgramSpecification
-
- getPredicateClassName() - Method in class io.cdap.cdap.api.workflow.WorkflowConditionNode
-
- getProcessed() - Method in interface io.cdap.cdap.api.metrics.RuntimeMetrics
-
- getProcessState() - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.ConsumablePartition
-
- getProcessState() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.DefaultConsumablePartition
-
- getProgram() - Method in interface io.cdap.cdap.api.schedule.ProgramStatusTriggerInfo
-
- getProgram() - Method in class io.cdap.cdap.api.workflow.WorkflowActionNode
-
- getProgramName() - Method in class io.cdap.cdap.api.workflow.ScheduleProgramInfo
-
- getProgramName() - Method in class io.cdap.cdap.internal.schedule.ScheduleCreationSpec
-
- getProgramsByType(ProgramType) - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getProgramSchedules() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getProgramStatus() - Method in interface io.cdap.cdap.api.schedule.ProgramStatusTriggerInfo
-
- getProgramType() - Method in interface io.cdap.cdap.api.schedule.ProgramStatusTriggerInfo
-
- getProgramType() - Method in class io.cdap.cdap.api.workflow.ScheduleProgramInfo
-
- getProgress() - Method in class io.cdap.cdap.api.data.batch.RecordScanner
-
The current progress of the record reader through its data.
- getProgress() - Method in class io.cdap.cdap.api.data.batch.SplitReader
-
The current progress of the record reader through its data.
- getProperties() - Method in class io.cdap.cdap.api.artifact.ArtifactInfo
-
- getProperties() - Method in interface io.cdap.cdap.api.common.PropertyProvider
-
Returns an immutable Map of all properties.
- getProperties() - Method in class io.cdap.cdap.api.dataset.DatasetProperties
-
- getProperties() - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
Return map of all properties set in this specification.
- getProperties() - Method in class io.cdap.cdap.api.dataset.table.Scan
-
- getProperties() - Method in class io.cdap.cdap.api.mapreduce.MapReduceSpecification
-
- getProperties() - Method in class io.cdap.cdap.api.metadata.Metadata
-
- getProperties() - Method in class io.cdap.cdap.api.plugin.Plugin
-
Returns the set of properties available when the plugin was created.
- getProperties() - Method in class io.cdap.cdap.api.plugin.PluginClass
-
Returns a map from config property name to
PluginPropertyField
that are supported by the plugin class.
- getProperties() - Method in class io.cdap.cdap.api.plugin.PluginConfig
-
- getProperties() - Method in class io.cdap.cdap.api.plugin.PluginProperties
-
- getProperties() - Method in interface io.cdap.cdap.api.schedule.TriggeringScheduleInfo
-
- getProperties() - Method in class io.cdap.cdap.api.security.store.SecureStoreMetadata
-
- getProperties() - Method in class io.cdap.cdap.api.service.http.HttpServiceHandlerSpecification
-
- getProperties() - Method in class io.cdap.cdap.api.service.ServiceSpecification
-
- getProperties() - Method in class io.cdap.cdap.api.spark.SparkHttpServiceHandlerSpecification
-
- getProperties() - Method in class io.cdap.cdap.api.spark.SparkSpecification
-
- getProperties() - Method in class io.cdap.cdap.api.worker.WorkerSpecification
-
- getProperties() - Method in class io.cdap.cdap.api.workflow.WorkflowSpecification
-
- getProperties() - Method in class io.cdap.cdap.internal.app.runtime.schedule.DefaultTriggeringScheduleInfo
-
- getProperties() - Method in class io.cdap.cdap.internal.customaction.DefaultCustomActionSpecification
-
- getProperties() - Method in class io.cdap.cdap.internal.dataset.DatasetCreationSpec
-
- getProperties() - Method in class io.cdap.cdap.internal.schedule.ScheduleCreationSpec
-
- getProperties() - Method in class io.cdap.cdap.internal.workflow.condition.DefaultConditionSpecification
-
- getProperty(String) - Method in interface io.cdap.cdap.api.common.PropertyProvider
-
Return the property value of a given key.
- getProperty(String) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
Lookup a custom property of the dataset.
- getProperty(String, String) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
Lookup a custom property of the dataset.
- getProperty(String) - Method in class io.cdap.cdap.api.mapreduce.MapReduceSpecification
-
- getProperty(String) - Method in class io.cdap.cdap.api.service.http.HttpServiceHandlerSpecification
-
- getProperty(String) - Method in class io.cdap.cdap.api.service.ServiceSpecification
-
- getProperty(String) - Method in class io.cdap.cdap.api.spark.SparkHttpServiceHandlerSpecification
-
- getProperty(String) - Method in class io.cdap.cdap.api.spark.SparkSpecification
-
- getProperty(String) - Method in class io.cdap.cdap.api.worker.WorkerSpecification
-
- getProperty(String) - Method in class io.cdap.cdap.api.workflow.WorkflowSpecification
-
- getProperty(String) - Method in class io.cdap.cdap.internal.customaction.DefaultCustomActionSpecification
-
- getProperty(String) - Method in class io.cdap.cdap.internal.workflow.condition.DefaultConditionSpecification
-
- getRawProperties() - Method in class io.cdap.cdap.api.plugin.PluginConfig
-
- getRawType() - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Returns the raw type of T
.
- getRawType() - Method in class io.cdap.cdap.internal.io.TypeRepresentation
-
- getReadlessIncrementSupport(DatasetProperties) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getReadlessIncrementSupport(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getRecordType() - Method in interface io.cdap.cdap.api.data.batch.RecordScannable
-
The type of records that the dataset exposes as a schema.
- getRecordType() - Method in interface io.cdap.cdap.api.data.batch.RecordWritable
-
The type of records that the dataset exposes as a schema.
- getRecordType() - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- getRecordType() - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
- getReducerResources() - Method in class io.cdap.cdap.api.mapreduce.MapReduceSpecification
-
- getRelativePath() - Method in interface io.cdap.cdap.api.dataset.lib.Partition
-
- getRequestURI() - Method in interface io.cdap.cdap.api.service.http.HttpServiceRequest
-
- getRequirements() - Method in class io.cdap.cdap.api.artifact.ApplicationClass
-
- getRequirements() - Method in class io.cdap.cdap.api.plugin.PluginClass
-
- getResolution() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeDeleteQuery
-
- getResolution() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeExploreQuery
-
- getResolution() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery
-
- getResources() - Method in class io.cdap.cdap.api.service.ServiceSpecification
-
Returns the resources requirements for the service handler.
- getResources() - Method in class io.cdap.cdap.api.worker.WorkerSpecification
-
- getRetries() - Method in exception io.cdap.cdap.api.retry.RetriesExhaustedException
-
Return the retry count set
- getRetries() - Method in interface io.cdap.cdap.api.retry.RetryCountProvider
-
Return the retry count
- getRetries() - Method in exception io.cdap.cdap.api.retry.RetryFailedException
-
Return the retry count
- getReturnType() - Method in class io.cdap.cdap.internal.guava.reflect.Invokable
-
Returns the return type of this Invokable
.
- getRow() - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getRow() - Method in class io.cdap.cdap.api.dataset.table.Increment
-
- getRow() - Method in class io.cdap.cdap.api.dataset.table.Put
-
- getRow() - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getRow() - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getRow() - Method in class io.cdap.cdap.api.dataset.table.RowColumns
-
- getRowFieldName(DatasetProperties) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getRowFieldName(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getRowKeyExploreName(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.ObjectMappedTableProperties
-
- getRowKeyExploreType(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.ObjectMappedTableProperties
-
- getRunId() - Method in interface io.cdap.cdap.api.RuntimeContext
-
- getRunId() - Method in interface io.cdap.cdap.api.schedule.ProgramStatusTriggerInfo
-
- getRunId() - Method in interface io.cdap.cdap.api.workflow.WorkflowInfo
-
- getRunId() - Method in class io.cdap.cdap.api.workflow.WorkflowNodeState
-
Return the run id if node represents programs, such as MapReduce or Spark.
- getRuntimeArguments() - Method in interface io.cdap.cdap.api.dataset.lib.FileSet
-
Allow direct access to the runtime arguments of this file set.
- getRuntimeArguments() - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Allow direct access to the runtime arguments of this partitioned file set.
- getRuntimeArguments() - Method in interface io.cdap.cdap.api.RuntimeContext
-
- getRuntimeArguments() - Method in interface io.cdap.cdap.api.schedule.ProgramStatusTriggerInfo
-
- getSchema(DatasetProperties) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getSchema(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getScope() - Method in class io.cdap.cdap.api.artifact.ArtifactId
-
get the scope of artifact
- getScope() - Method in class io.cdap.cdap.api.artifact.ArtifactSummary
-
get the scope of the artifact
- getSerDe(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getServices() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getServiceURL(String, String, String) - Method in interface io.cdap.cdap.api.ServiceDiscoverer
-
Discover the base URL for a Service of an Application running in a Namespace, relative to which Service endpoints
can be accessed
- getServiceURL(String, String) - Method in interface io.cdap.cdap.api.ServiceDiscoverer
-
Discover the base URL for a Service, relative to which Service endpoints can be accessed
- getServiceURL(String) - Method in interface io.cdap.cdap.api.ServiceDiscoverer
-
Discover the base URL for a Service in the same application, relative to which Service endpoints can be accessed
- getShort(byte[]) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getShort(byte[], short) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getShort(String) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getShort(String, short) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getShort(byte[]) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getShort(byte[], short) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getShort(String) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getShort(String, short) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getShort(byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getShort(byte[], short) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getShort(String) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getShort(String, short) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getShort(Object) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- getShort(Object) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- getSource() - Method in class io.cdap.cdap.api.lineage.field.ReadOperation
-
- getSpark() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getSpecification() - Method in interface io.cdap.cdap.api.customaction.CustomActionContext
-
Return the specification of the custom action.
- getSpecification(String) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
Get the specification for an embedded dataset.
- getSpecification() - Method in interface io.cdap.cdap.api.mapreduce.MapReduceContext
-
- getSpecification() - Method in interface io.cdap.cdap.api.mapreduce.MapReduceTaskContext
-
- getSpecification() - Method in interface io.cdap.cdap.api.service.http.HttpServiceContext
-
- getSpecification() - Method in interface io.cdap.cdap.api.service.ServiceContext
-
Returns the specification used to configure
Service
bounded to this context.
- getSpecification() - Method in interface io.cdap.cdap.api.spark.SparkClientContext
-
- getSpecification() - Method in interface io.cdap.cdap.api.worker.WorkerContext
-
Returns the specification used to configure
Worker
bounded to this context.
- getSpecifications() - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
- getSplits() - Method in interface io.cdap.cdap.api.data.batch.BatchReadable
-
Returns all splits of the dataset.
- getSplits() - Method in class io.cdap.cdap.api.data.batch.Input.DatasetInput
-
- getSplits() - Method in interface io.cdap.cdap.api.data.batch.RecordScannable
-
Returns all splits of the dataset.
- getSplits(int, byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- getSplits() - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- getSplits() - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
- getSplits(int, byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
Returns splits for a range of keys in the table.
- getSplits(int, byte[], byte[]) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectMappedTable
-
Returns splits for a range of keys in the table.
- getSplits(int, byte[], byte[]) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectStore
-
Returns splits for a range of keys in the table.
- getSplits() - Method in class io.cdap.cdap.api.dataset.lib.TimeseriesTable
-
- getSplits(int, byte[], byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Returns splits for a range of keys in the table.
- getStart() - Method in class io.cdap.cdap.api.dataset.table.TableSplit
-
- getStartRow() - Method in class io.cdap.cdap.api.dataset.table.Scan
-
- getStartTs() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeDeleteQuery
-
- getStartTs() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeExploreQuery
-
- getStartTs() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery
-
- getStartVersion() - Method in class io.cdap.cdap.api.dataset.lib.PartitionConsumerState
-
- getState() - Method in interface io.cdap.cdap.api.customaction.CustomActionContext
-
Return the state of the custom action.
- getState() - Method in interface io.cdap.cdap.api.mapreduce.MapReduceContext
-
Return the state of the MapReduce program.
- getState() - Method in interface io.cdap.cdap.api.spark.SparkClientContext
-
Return the state of the Spark program.
- getState() - Method in interface io.cdap.cdap.api.workflow.WorkflowContext
-
Return the state of the workflow.
- getStatePersistor() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.AbstractPartitionConsumer
-
- getStatus() - Method in class io.cdap.cdap.api.ProgramState
-
- getStatusCode() - Method in interface io.cdap.cdap.api.common.HttpErrorStatusProvider
-
Gives the HTTP status code for this error.
- getStop() - Method in class io.cdap.cdap.api.dataset.table.TableSplit
-
- getStopRow() - Method in class io.cdap.cdap.api.dataset.table.Scan
-
- getString(byte[]) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getString(String) - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- getString(byte[]) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getString(String) - Method in class io.cdap.cdap.api.dataset.table.Result
-
- getString(byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getString(String) - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- getSubtype(Class<?>) - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Returns subtype of this
with subclass
as the raw class.
- getSuffix() - Method in class io.cdap.cdap.api.artifact.ArtifactVersion
-
get the artifact version suffix
- getSupertype(Class<? super T>) - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Returns the generic form of superclass
.
- getTablePermissions(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getTableProperties(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- getTagPredicate() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeDeleteQuery
-
- getTags() - Method in class io.cdap.cdap.api.dataset.lib.CounterTimeseriesTable.Counter
-
Returns the tags associated with the counter.
- getTags() - Method in class io.cdap.cdap.api.metadata.Metadata
-
- getTags() - Method in interface io.cdap.cdap.api.metrics.Metrics
-
- getTime() - Method in interface io.cdap.cdap.api.dataset.lib.TimePartition
-
- getTimeout() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerConfiguration
-
Defines an expiration timeout, in seconds, of IN_PROGRESS partitions
- getTimeoutMillis() - Method in class io.cdap.cdap.internal.schedule.ScheduleCreationSpec
-
- getTimestamp() - Method in class io.cdap.cdap.api.dataset.lib.CounterTimeseriesTable.Counter
-
Returns the timestamp of the counter.
- getTimestamp() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeFact
-
- getTimestamp() - Method in class io.cdap.cdap.api.dataset.lib.cube.TimeValue
-
- getTimestamp() - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.ConsumablePartition
-
- getTimestamp() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.DefaultConsumablePartition
-
- getTimeValues() - Method in class io.cdap.cdap.api.dataset.lib.cube.TimeSeries
-
- getToken() - Method in interface io.cdap.cdap.api.workflow.WorkflowContext
-
- getTopic() - Method in exception io.cdap.cdap.api.messaging.MessagingException
-
- getTopicProperties(String) - Method in interface io.cdap.cdap.api.messaging.MessagingAdmin
-
Returns the properties of a topic.
- getTransactionAwareName() - Method in class io.cdap.cdap.api.dataset.lib.AbstractDataset
-
- getTrigger() - Method in class io.cdap.cdap.internal.schedule.ScheduleCreationSpec
-
- getTriggerFactory() - Method in class io.cdap.cdap.api.app.AbstractApplication
-
Get a TriggerFactory to get triggers.
- getTriggerFactory() - Method in interface io.cdap.cdap.api.app.ApplicationConfigurer
-
Get a TriggerFactory to get triggers.
- getTriggerInfos() - Method in interface io.cdap.cdap.api.schedule.TriggeringScheduleInfo
-
- getTriggerInfos() - Method in class io.cdap.cdap.internal.app.runtime.schedule.DefaultTriggeringScheduleInfo
-
- getTriggeringScheduleInfo() - Method in interface io.cdap.cdap.api.SchedulableProgramContext
-
- getTTL(DatasetProperties) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getTTL(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
- getTxChanges() - Method in class io.cdap.cdap.api.dataset.lib.AbstractDataset
-
- getType() - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
Returns the type of the dataset.
- getType() - Method in class io.cdap.cdap.api.dataset.lib.cube.Measurement
-
- getType() - Method in class io.cdap.cdap.api.lineage.field.Operation
-
- getType() - Method in class io.cdap.cdap.api.metadata.MetadataEntity
-
- getType() - Method in class io.cdap.cdap.api.plugin.PluginClass
-
Returns the type name of the plugin.
- getType() - Method in class io.cdap.cdap.api.plugin.PluginPropertyField
-
Returns the type of the property.
- getType() - Method in interface io.cdap.cdap.api.schedule.Trigger
-
- getType() - Method in interface io.cdap.cdap.api.schedule.TriggerInfo
-
- getType() - Method in class io.cdap.cdap.api.workflow.WorkflowNode
-
- getType() - Method in class io.cdap.cdap.internal.guava.reflect.Parameter
-
Returns the type of the parameter.
- getType() - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Returns the represented type.
- getType() - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- getType() - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- getTypeName() - Method in class io.cdap.cdap.internal.dataset.DatasetCreationSpec
-
- getTypes() - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Returns the set of interfaces and classes that this type is or is a subtype of.
- getUpdateActions() - Method in interface io.cdap.cdap.api.app.ApplicationUpdateContext
-
- getUpper() - Method in class io.cdap.cdap.api.artifact.ArtifactVersionRange
-
upper version of artifact range
- getUpper() - Method in class io.cdap.cdap.api.dataset.lib.PartitionFilter.Condition
-
- getUserId() - Method in interface io.cdap.cdap.api.service.http.HttpServiceRequest
-
- getValue() - Method in class io.cdap.cdap.api.dataset.lib.CounterTimeseriesTable.Counter
-
Returns the count value of the counter.
- getValue() - Method in class io.cdap.cdap.api.dataset.lib.cube.DimensionValue
-
- getValue() - Method in class io.cdap.cdap.api.dataset.lib.cube.Measurement
-
- getValue() - Method in class io.cdap.cdap.api.dataset.lib.cube.TimeValue
-
- getValue() - Method in class io.cdap.cdap.api.dataset.lib.KeyValue
-
- getValue() - Method in class io.cdap.cdap.api.dataset.lib.PartitionFilter.Condition
-
- getValue(String) - Method in class io.cdap.cdap.api.metadata.MetadataEntity
-
- getValue() - Method in class io.cdap.cdap.api.metadata.MetadataEntity.KeyValue
-
- getValue() - Method in class io.cdap.cdap.api.workflow.NodeValue
-
- getValues() - Method in class io.cdap.cdap.api.dataset.table.Increment
-
- getValues() - Method in class io.cdap.cdap.api.dataset.table.Put
-
- getVersion() - Method in class io.cdap.cdap.api.artifact.ArtifactId
-
get the version of artifact
- getVersion() - Method in class io.cdap.cdap.api.artifact.ArtifactSummary
-
get the version of artifact
- getVersion() - Method in class io.cdap.cdap.api.artifact.ArtifactVersion
-
get the version string of artifact
- getVersion() - Static method in class io.cdap.cdap.api.PlatformInfo
-
- getVersionsToCheck() - Method in class io.cdap.cdap.api.dataset.lib.PartitionConsumerState
-
- getVersionString() - Method in class io.cdap.cdap.api.artifact.ArtifactVersionRange
-
- getVirtualCores() - Method in class io.cdap.cdap.api.Resources
-
Returns the number of virtual cores.
- getWorkers() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getWorkflowInfo() - Method in interface io.cdap.cdap.api.mapreduce.MapReduceTaskContext
-
- getWorkflowInfo() - Method in interface io.cdap.cdap.api.workflow.WorkflowInfoProvider
-
- getWorkflows() - Method in interface io.cdap.cdap.api.app.ApplicationSpecification
-
- getWorkflowSpecification() - Method in interface io.cdap.cdap.api.workflow.WorkflowContext
-
- getWorkflowToken() - Method in interface io.cdap.cdap.api.mapreduce.MapReduceTaskContext
-
- getWorkflowToken() - Method in interface io.cdap.cdap.api.schedule.ProgramStatusTriggerInfo
-
- getWorkflowToken() - Method in interface io.cdap.cdap.api.workflow.WorkflowInfoProvider
-
- groupBy() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery.Builder.GroupBy
-
- IncompatibleUpdateException - Exception in io.cdap.cdap.api.dataset
-
Exception thrown when a dataset instance is reconfigured in an incompatible way.
- IncompatibleUpdateException(String) - Constructor for exception io.cdap.cdap.api.dataset.IncompatibleUpdateException
-
- increment(byte[], long, long, byte[]...) - Method in class io.cdap.cdap.api.dataset.lib.CounterTimeseriesTable
-
Increments the value for a counter for a row and timestamp.
- increment(byte[], byte[], long) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Increments (atomically) the specified row and column by the specified amount, without returning the new value.
- increment(byte[], byte[][], long[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Increments (atomically) the specified row and columns by the specified amounts, without returning the new values.
- increment(Increment) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Increments (atomically) the specified row and columns by the specified amounts, without returning the new values.
- increment(byte[], long) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
Increment the value of a key by amount; the key must either not exist yet, or the
current value at the key must be 8 bytes long to be interpretable as a long.
- Increment - Class in io.cdap.cdap.api.dataset.table
-
An Increment interprets the values of columns as 8-byte integers and
increments them by the specified value.
- Increment(byte[]) - Constructor for class io.cdap.cdap.api.dataset.table.Increment
-
Changes the values of columns in a row.
- Increment(byte[], byte[], long) - Constructor for class io.cdap.cdap.api.dataset.table.Increment
-
Changes the value of at least one column in a row.
- Increment(String) - Constructor for class io.cdap.cdap.api.dataset.table.Increment
-
Changes the values of all of the columns in a row.
- Increment(String, String, long) - Constructor for class io.cdap.cdap.api.dataset.table.Increment
-
Changes the value of at least one column in a row.
- increment(byte[], byte[], long) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Increments (atomically) the specified row and columns by the specified amounts, without returning the new value.
- increment(byte[], byte[][], long[]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Increments (atomically) the specified row and columns by the specified amounts, without returning the new values.
- increment(Increment) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Increments (atomically) the specified row and columns by the specified amounts, without returning the new values.
- increment(String, long) - Method in interface io.cdap.cdap.api.metrics.MetricsCollector
-
Increment a metric value at the current time.
- incrementAndGet(byte[], byte[], long) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Increments (atomically) the specified row and column by the specified amount, and returns the new value.
- incrementAndGet(byte[], byte[][], long[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Increments (atomically) the specified row and columns by the specified amounts, and returns the new values.
- incrementAndGet(Increment) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Increments (atomically) the specified row and columns by the specified amounts, and returns the new values.
- incrementAndGet(byte[], long) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
Increment the value for a given key and return the resulting value.
- incrementAndGet(byte[], byte[], long) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Increments the specified column of the row by the specified amount and returns the new value.
- incrementAndGet(byte[], byte[][], long[]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Increments the specified columns of the row by the specified amounts and returns the new values.
- incrementAndGet(Increment) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Increments the specified columns of a row by the specified amounts defined by the
Increment
parameter and
returns the new values
- incrementNumFailures() - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.ConsumablePartition
-
- incrementNumFailures() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.DefaultConsumablePartition
-
- INDEX_COLUMNS_CONF_KEY - Static variable in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Configuration key for defining column names to index in the DatasetSpecification properties.
- IndexedObjectStore<T> - Class in io.cdap.cdap.api.dataset.lib
-
An ObjectStore Dataset extension that supports access to objects via indices; lookups by the index will return
all the objects stored in the object store that have the index value.
- IndexedObjectStore(String, ObjectStore<T>, Table) - Constructor for class io.cdap.cdap.api.dataset.lib.IndexedObjectStore
-
Constructs the IndexedObjectStore with name and type.
- IndexedObjectStoreDefinition - Class in io.cdap.cdap.api.dataset.lib
-
- IndexedObjectStoreDefinition(String, DatasetDefinition<? extends Table, ?>, DatasetDefinition<? extends ObjectStore, ?>) - Constructor for class io.cdap.cdap.api.dataset.lib.IndexedObjectStoreDefinition
-
- IndexedTable - Class in io.cdap.cdap.api.dataset.lib
-
Implements a table that creates and maintains indexes on values stored within a configured set of column names.
- IndexedTable(String, Table, Table, SortedSet<byte[]>) - Constructor for class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Configuration time constructor.
- IndexedTable(String, Table, Table, SortedSet<byte[]>, byte[]) - Constructor for class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Configuration time constructor.
- IndexedTableDefinition - Class in io.cdap.cdap.api.dataset.lib
-
- IndexedTableDefinition(String, DatasetDefinition<? extends Table, ?>) - Constructor for class io.cdap.cdap.api.dataset.lib.IndexedTableDefinition
-
- info(String, Object) - Method in interface io.cdap.cdap.api.preview.DataTracer
-
Traces the data.
- initialize(CustomActionContext) - Method in class io.cdap.cdap.api.customaction.AbstractCustomAction
-
- initialize() - Method in class io.cdap.cdap.api.customaction.AbstractCustomAction
-
- initialize(Split) - Method in class io.cdap.cdap.api.data.batch.IteratorBasedSplitReader
-
- initialize(Split) - Method in class io.cdap.cdap.api.data.batch.RecordScanner
-
Called once at initialization.
- initialize(Split) - Method in class io.cdap.cdap.api.data.batch.SplitReader
-
Called once at initialization.
- initialize(Split) - Method in class io.cdap.cdap.api.data.batch.SplitReaderAdapter
-
- initialize(MapReduceTaskContext<K, V>) - Method in class io.cdap.cdap.api.dataset.lib.DynamicPartitioner
-
Initializes a DynamicPartitioner.
- initialize(Split) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable.KeyValueScanner
-
- initialize(MapReduceContext) - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
- initialize() - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
- initialize(T) - Method in interface io.cdap.cdap.api.ProgramLifecycle
-
Initializes a Program.
- initialize(V) - Method in class io.cdap.cdap.api.service.AbstractService
-
- initialize(T) - Method in class io.cdap.cdap.api.service.http.AbstractHttpServiceHandler
-
- initialize(T) - Method in interface io.cdap.cdap.api.service.http.HttpServiceHandler
-
Invoked whenever a new instance of this HttpServiceHandler is created.
- initialize(V) - Method in interface io.cdap.cdap.api.service.Service
-
Initialize the Service
.
- initialize(SparkClientContext) - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
- initialize() - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
- initialize(WorkerContext) - Method in class io.cdap.cdap.api.worker.AbstractWorker
-
- initialize(WorkerContext) - Method in interface io.cdap.cdap.api.worker.Worker
-
Initialize the Worker
.
- initialize(WorkflowContext) - Method in class io.cdap.cdap.api.workflow.AbstractCondition
-
- initialize(WorkflowContext) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- Input - Class in io.cdap.cdap.api.data.batch
-
Defines input to a program, such as MapReduce.
- Input.DatasetInput - Class in io.cdap.cdap.api.data.batch
-
An implementation of
Input
, which defines a
Dataset
as an input.
- Input.InputFormatProviderInput - Class in io.cdap.cdap.api.data.batch
-
- INPUT_END_TIME - Static variable in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
- INPUT_FORMAT - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
The name of the input format class.
- INPUT_PARTITION_FILTER - Static variable in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
- INPUT_PARTITION_LIST - Static variable in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
- INPUT_PATHS - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetArguments
-
The paths of the files to be read.
- INPUT_PROPERTIES_PREFIX - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
Prefix for additional properties for the input format.
- INPUT_START_TIME - Static variable in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
- InputContext - Interface in io.cdap.cdap.api.data.batch
-
Exposes information about the input configured for this task.
- InputField - Class in io.cdap.cdap.api.lineage.field
-
Represents an input field of an operation.
- InputFormatProvider - Interface in io.cdap.cdap.api.data.batch
-
Interface to be implemented by datasets used as input to a MapReduce.
- InputSplit() - Constructor for class io.cdap.cdap.api.dataset.lib.TimeseriesTable.InputSplit
-
Constructor for serialization only.
- InstanceConflictException - Exception in io.cdap.cdap.api.dataset
-
Thrown when operation conflicts with existing dataset instances available in the system.
- InstanceConflictException(String) - Constructor for exception io.cdap.cdap.api.dataset.InstanceConflictException
-
- InstanceConflictException(String, Throwable) - Constructor for exception io.cdap.cdap.api.dataset.InstanceConflictException
-
- InstanceNotFoundException - Exception in io.cdap.cdap.api.dataset
-
Thrown for an operation on a non-existing dataset instance.
- InstanceNotFoundException(String) - Constructor for exception io.cdap.cdap.api.dataset.InstanceNotFoundException
-
- InstanceNotFoundException(String, Throwable) - Constructor for exception io.cdap.cdap.api.dataset.InstanceNotFoundException
-
- interfaces() - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken.TypeSet
-
Returns the types that are interfaces implemented by this type.
- interpolate(TimeValue, TimeValue, long) - Method in interface io.cdap.cdap.api.dataset.lib.cube.Interpolator
-
Given start and end TimeValues, and a time in-between the two, return a TimeValue for the in-between time.
- interpolate(TimeValue, TimeValue, long) - Method in class io.cdap.cdap.api.dataset.lib.cube.Interpolators.BaseInterpolator
-
- interpolator(Interpolator) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery.Builder.Limit
-
- Interpolator - Interface in io.cdap.cdap.api.dataset.lib.cube
-
Defines how to interpolate a value between two other time values.
- Interpolators - Class in io.cdap.cdap.api.dataset.lib.cube
-
Returns interpolators of different types.
- Interpolators() - Constructor for class io.cdap.cdap.api.dataset.lib.cube.Interpolators
-
- Interpolators.BaseInterpolator - Class in io.cdap.cdap.api.dataset.lib.cube
-
Return 0 if the time between data points is above a give limit, or if the point to interpolate
is too far before the first point, or too far after the last point.
- Interpolators.Linear - Class in io.cdap.cdap.api.dataset.lib.cube
-
timestamps between 2 data points will increase or decrease "linearly".
- Interpolators.Step - Class in io.cdap.cdap.api.dataset.lib.cube
-
Timestamps between 2 data points will take on the value of the previous point.
- InvalidArtifactRangeException - Exception in io.cdap.cdap.api.artifact
-
Thrown when an artifact range is invalid.
- InvalidArtifactRangeException(String) - Constructor for exception io.cdap.cdap.api.artifact.InvalidArtifactRangeException
-
- InvalidPluginConfigException - Exception in io.cdap.cdap.api.plugin
-
- InvalidPluginConfigException(String, Throwable) - Constructor for exception io.cdap.cdap.api.plugin.InvalidPluginConfigException
-
- InvalidPluginConfigException(PluginClass, Set<String>, Set<InvalidPluginProperty>) - Constructor for exception io.cdap.cdap.api.plugin.InvalidPluginConfigException
-
- InvalidPluginProperty - Class in io.cdap.cdap.api.plugin
-
An invalid plugin property.
- InvalidPluginProperty(String, String) - Constructor for class io.cdap.cdap.api.plugin.InvalidPluginProperty
-
- InvalidPluginProperty(String, Exception) - Constructor for class io.cdap.cdap.api.plugin.InvalidPluginProperty
-
- Invokable<T,R> - Class in io.cdap.cdap.internal.guava.reflect
-
- invoke(T, Object...) - Method in class io.cdap.cdap.internal.guava.reflect.Invokable
-
Invokes with receiver
as 'this' and args
passed to the underlying method
and returns the return value; or calls the underlying constructor with args
and returns
the constructed instance.
- io.cdap.cdap.api - package io.cdap.cdap.api
-
Interfaces for program and resource specifications, program lifecycle, runtime context and processors.
- io.cdap.cdap.api.annotation - package io.cdap.cdap.api.annotation
-
Annotations used when creating Applications.
- io.cdap.cdap.api.app - package io.cdap.cdap.api.app
-
An Application is a logical grouping of
Datasets
and programs.
- io.cdap.cdap.api.artifact - package io.cdap.cdap.api.artifact
-
Classes related to artifacts.
- io.cdap.cdap.api.builder - package io.cdap.cdap.api.builder
-
Interfaces for constructing specifications.
- io.cdap.cdap.api.common - package io.cdap.cdap.api.common
-
Commonly used utility functions.
- io.cdap.cdap.api.customaction - package io.cdap.cdap.api.customaction
-
- io.cdap.cdap.api.data - package io.cdap.cdap.api.data
-
Defines means of integration between programs and data access.
- io.cdap.cdap.api.data.batch - package io.cdap.cdap.api.data.batch
-
Allows MapReduce jobs to read from and write to datasets.
- io.cdap.cdap.api.dataset - package io.cdap.cdap.api.dataset
-
Defines APIs for accessing and managing data within CDAP.
- io.cdap.cdap.api.dataset.lib - package io.cdap.cdap.api.dataset.lib
-
Collection of
Dataset
implementations available out-of-the-box in CDAP.
- io.cdap.cdap.api.dataset.lib.app.partitioned - package io.cdap.cdap.api.dataset.lib.app.partitioned
-
- io.cdap.cdap.api.dataset.lib.cube - package io.cdap.cdap.api.dataset.lib.cube
-
Implementation of a Cube dataset in CDAP.
- io.cdap.cdap.api.dataset.lib.partitioned - package io.cdap.cdap.api.dataset.lib.partitioned
-
Implementation of classes which use partitioned datasets (such as partition consumers) in CDAP.
- io.cdap.cdap.api.dataset.metrics - package io.cdap.cdap.api.dataset.metrics
-
Defines integration points for
Dataset
s and Metrics system.
- io.cdap.cdap.api.dataset.module - package io.cdap.cdap.api.dataset.module
-
Defines deployment of custom
Dataset
s to make them available within CDAP.
- io.cdap.cdap.api.dataset.table - package io.cdap.cdap.api.dataset.table
-
Provides access to the system-level table
Dataset
s available within CDAP.
- io.cdap.cdap.api.feature - package io.cdap.cdap.api.feature
-
- io.cdap.cdap.api.lineage.field - package io.cdap.cdap.api.lineage.field
-
- io.cdap.cdap.api.macro - package io.cdap.cdap.api.macro
-
- io.cdap.cdap.api.mapreduce - package io.cdap.cdap.api.mapreduce
-
Defines MapReduce jobs.
- io.cdap.cdap.api.messaging - package io.cdap.cdap.api.messaging
-
Classes and interfaces for interacting with the Transactional Messaging System.
- io.cdap.cdap.api.metadata - package io.cdap.cdap.api.metadata
-
- io.cdap.cdap.api.metrics - package io.cdap.cdap.api.metrics
-
Defines a way to collect user-defined metrics.
- io.cdap.cdap.api.plugin - package io.cdap.cdap.api.plugin
-
Packages for plugins in CDAP.
- io.cdap.cdap.api.preview - package io.cdap.cdap.api.preview
-
- io.cdap.cdap.api.retry - package io.cdap.cdap.api.retry
-
- io.cdap.cdap.api.schedule - package io.cdap.cdap.api.schedule
-
For running programs periodically.
- io.cdap.cdap.api.security - package io.cdap.cdap.api.security
-
- io.cdap.cdap.api.security.store - package io.cdap.cdap.api.security.store
-
- io.cdap.cdap.api.service - package io.cdap.cdap.api.service
-
Defines ServiceSpecification.
- io.cdap.cdap.api.service.http - package io.cdap.cdap.api.service.http
-
Defines a service for handling HTTP requests.
- io.cdap.cdap.api.spark - package io.cdap.cdap.api.spark
-
Defines APIs for defining Spark jobs in CDAP.
- io.cdap.cdap.api.worker - package io.cdap.cdap.api.worker
-
Configuration and specification of workers in CDAP.
- io.cdap.cdap.api.workflow - package io.cdap.cdap.api.workflow
-
For constructing workflows.
- io.cdap.cdap.internal - package io.cdap.cdap.internal
-
This package contains internal classes for supporting the CDAP API.
- io.cdap.cdap.internal.api - package io.cdap.cdap.internal.api
-
This package contains internal classes for supporting the CDAP API.
- io.cdap.cdap.internal.app.runtime.schedule - package io.cdap.cdap.internal.app.runtime.schedule
-
- io.cdap.cdap.internal.customaction - package io.cdap.cdap.internal.customaction
-
- io.cdap.cdap.internal.dataset - package io.cdap.cdap.internal.dataset
-
This package contains internal classes for supporting the CDAP API.
- io.cdap.cdap.internal.flow - package io.cdap.cdap.internal.flow
-
This package contains internal classes for supporting the CDAP API.
- io.cdap.cdap.internal.flowlet - package io.cdap.cdap.internal.flowlet
-
This package contains internal classes for supporting the CDAP API.
- io.cdap.cdap.internal.guava.reflect - package io.cdap.cdap.internal.guava.reflect
-
This package contains utilities to work with Java reflection.
- io.cdap.cdap.internal.io - package io.cdap.cdap.internal.io
-
This package contains internal classes for supporting the CDAP API.
- io.cdap.cdap.internal.lang - package io.cdap.cdap.internal.lang
-
This package contains internal classes for supporting the CDAP API.
- io.cdap.cdap.internal.schedule - package io.cdap.cdap.internal.schedule
-
This package contains internal classes for supporting the CDAP API.
- io.cdap.cdap.internal.schedule.constraint - package io.cdap.cdap.internal.schedule.constraint
-
- io.cdap.cdap.internal.specification - package io.cdap.cdap.internal.specification
-
This package contains internal classes for supporting the CDAP API.
- io.cdap.cdap.internal.workflow - package io.cdap.cdap.internal.workflow
-
This package contains internal classes for supporting the CDAP API.
- io.cdap.cdap.internal.workflow.condition - package io.cdap.cdap.internal.workflow.condition
-
- isAnnotationPresent(Class<? extends Annotation>) - Method in class io.cdap.cdap.internal.guava.reflect.Parameter
-
- isArray() - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Returns true if this type is known to be an array type, such as int[]
, T[]
,
<? extends Map<String, Integer>[]>
etc.
- isAssignableFrom(TypeToken<?>) - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Returns true if this type is assignable from the given type
.
- isAssignableFrom(Type) - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Check if this type is assignable from the given type
.
- isBaseOutputPath(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetArguments
-
- isDataExternal(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- isDynamicPartitionerConcurrencyAllowed(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Determines whether concurrent writers are allowed in the case of DynamicPartitioner.
- isEmpty() - Method in class io.cdap.cdap.api.dataset.lib.PartitionFilter.Builder
-
- isEmpty() - Method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- isEmpty() - Method in class io.cdap.cdap.api.dataset.table.Result
-
- isEmpty() - Method in interface io.cdap.cdap.api.dataset.table.Row
-
- isEmpty() - Method in class io.cdap.cdap.api.plugin.Requirements
-
- isEnabled() - Method in interface io.cdap.cdap.api.preview.DataTracer
-
Returns true
if application is running in preview mode otherwise false is returned.
- isEndState() - Method in enum io.cdap.cdap.api.workflow.NodeStatus
-
Returns true
if the status is an end status for an execution.
- isEscapingEnabled() - Method in class io.cdap.cdap.api.macro.MacroParserOptions
-
- isExactVersion() - Method in class io.cdap.cdap.api.artifact.ArtifactVersionRange
-
- isExploreEnabled(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- isFeatureEnabled(String) - Method in interface io.cdap.cdap.api.feature.FeatureFlagsProvider
-
This method tells is feature flag is currently enabled.
- isLowerInclusive - Variable in class io.cdap.cdap.api.artifact.ArtifactVersionRange
-
- isLowerInclusive() - Method in class io.cdap.cdap.api.artifact.ArtifactVersionRange
-
- isMacroEscapingEnabled() - Method in class io.cdap.cdap.api.plugin.PluginPropertyField
-
Returns true
if the macro escaping is enabled, false
otherwise.
- isMacroSupported() - Method in class io.cdap.cdap.api.plugin.PluginPropertyField
-
Returns true
if the property supports macro, false
otherwise.
- isOverridable() - Method in class io.cdap.cdap.internal.guava.reflect.Invokable
-
Returns true
if this is an overridable method.
- isParent(String) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
Returns true if the datasetName is the name of a non-composite dataset represented by this spec.
- isPossessExisting(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- isPrimitive() - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Returns true if this type is one of the nine primitive types (including void
).
- isRequired() - Method in class io.cdap.cdap.api.plugin.PluginPropertyField
-
Returns true
if the property is required by the plugin, false
otherwise.
- isResolved(Type) - Static method in class io.cdap.cdap.internal.lang.Reflections
-
Checks if the given type is fully resolved.
- isSingleValue() - Method in class io.cdap.cdap.api.dataset.lib.PartitionFilter.Condition
-
- isSnapshot() - Method in class io.cdap.cdap.api.artifact.ArtifactVersion
-
get if artifact version is a snapshot version
- isSnapshot() - Method in class io.cdap.cdap.api.PlatformInfo.Version
-
- isUpdateSupported() - Method in interface io.cdap.cdap.api.app.Application
-
Returns if application supports config update or not.
- isUpperInclusive - Variable in class io.cdap.cdap.api.artifact.ArtifactVersionRange
-
- isUpperInclusive() - Method in class io.cdap.cdap.api.artifact.ArtifactVersionRange
-
- isUseExisting(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- isVarArgs() - Method in class io.cdap.cdap.internal.guava.reflect.Invokable
-
Returns true
if this was declared to take a variable number of arguments.
- iterator() - Method in class io.cdap.cdap.api.dataset.lib.PartitionMetadata
-
- iterator() - Method in class io.cdap.cdap.api.metadata.MetadataEntity
-
- iterator() - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken.TypeSet
-
- IteratorBasedSplitReader<KEY,VALUE> - Class in io.cdap.cdap.api.data.batch
-
- IteratorBasedSplitReader() - Constructor for class io.cdap.cdap.api.data.batch.IteratorBasedSplitReader
-
- OBJECT_SCHEMA - Static variable in class io.cdap.cdap.api.dataset.lib.ObjectMappedTableProperties
-
The schema of objects in the table.
- OBJECT_TYPE - Static variable in class io.cdap.cdap.api.dataset.lib.ObjectMappedTableProperties
-
The type of object in the table.
- ObjectMappedTable<T> - Interface in io.cdap.cdap.api.dataset.lib
-
A Dataset that stores plain java Objects into a table by mapping object fields to table columns.
- ObjectMappedTableProperties - Class in io.cdap.cdap.api.dataset.lib
-
- ObjectMappedTableProperties() - Constructor for class io.cdap.cdap.api.dataset.lib.ObjectMappedTableProperties
-
- ObjectMappedTableProperties.Builder - Class in io.cdap.cdap.api.dataset.lib
-
- ObjectStore<T> - Interface in io.cdap.cdap.api.dataset.lib
-
A dataset that stores objects of a particular class into a table.
- objectStoreProperties(Type, DatasetProperties) - Static method in class io.cdap.cdap.api.dataset.lib.ObjectStores
-
- ObjectStores - Class in io.cdap.cdap.api.dataset.lib
-
Utility for describing
ObjectStore
and similar datasets within application configuration.
- of(String, InputFormatProvider) - Static method in class io.cdap.cdap.api.data.batch.Input
-
Returns an Input defined by an InputFormatProvider.
- of(String, OutputFormatProvider) - Static method in class io.cdap.cdap.api.data.batch.Output
-
Returns an Output defined by an OutputFormatProvider.
- of(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.DatasetProperties
-
Helper method to create a DatasetProperties from a map of key/values.
- of(byte[]) - Static method in class io.cdap.cdap.api.dataset.table.EmptyRow
-
- of(String) - Static method in class io.cdap.cdap.api.lineage.field.EndPoint
-
Return the EndPoint as defined by the provided name.
- of(String, String) - Static method in class io.cdap.cdap.api.lineage.field.EndPoint
-
Return the EndPoint as defined by the provided namespace and name.
- of(String, String) - Static method in class io.cdap.cdap.api.lineage.field.InputField
-
Creates an instance of an input field.
- of(boolean) - Static method in class io.cdap.cdap.api.workflow.Value
-
Return the
Value
representation of the input
boolean
parameter.
- of(int) - Static method in class io.cdap.cdap.api.workflow.Value
-
Return the
Value
representation of the input
int
parameter.
- of(long) - Static method in class io.cdap.cdap.api.workflow.Value
-
Return the
Value
representation of the input
long
parameter.
- of(double) - Static method in class io.cdap.cdap.api.workflow.Value
-
Return the
Value
representation of the input
double
parameter.
- of(String) - Static method in class io.cdap.cdap.api.workflow.Value
-
Return the
Value
representation of the input
String
parameter.
- of(Class<T>) - Static method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Returns an instance of type token that wraps type
.
- of(Type) - Static method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Returns an instance of type token that wraps type
.
- ofDataset(String) - Static method in class io.cdap.cdap.api.data.batch.Input
-
Returns an Input defined by a dataset.
- ofDataset(String, Map<String, String>) - Static method in class io.cdap.cdap.api.data.batch.Input
-
Returns an Input defined by a dataset.
- ofDataset(String, Iterable<? extends Split>) - Static method in class io.cdap.cdap.api.data.batch.Input
-
Returns an Input defined by a dataset.
- ofDataset(String, Map<String, String>, Iterable<? extends Split>) - Static method in class io.cdap.cdap.api.data.batch.Input
-
Returns an Input defined by a dataset.
- ofDataset(String) - Static method in class io.cdap.cdap.api.data.batch.Output
-
Returns an Output defined by a dataset.
- ofDataset(String, Map<String, String>) - Static method in class io.cdap.cdap.api.data.batch.Output
-
Returns an Output defined by a dataset.
- ofDataset(String) - Static method in class io.cdap.cdap.api.metadata.MetadataEntity
-
- ofDataset(String, String) - Static method in class io.cdap.cdap.api.metadata.MetadataEntity
-
Creates a
MetadataEntity
representing the given datasetName in the specified namespace.
- ofNamespace(String) - Static method in class io.cdap.cdap.api.metadata.MetadataEntity
-
- onError(HttpServiceResponder, Throwable) - Method in class io.cdap.cdap.api.service.http.HttpContentConsumer
-
This method is invoked when there is an error while processing the request body chunks.
- onError(Throwable) - Method in class io.cdap.cdap.api.service.http.HttpContentProducer
-
This method will get invoked when there is an error while sending body chunks.
- onFailure() - Method in interface io.cdap.cdap.api.data.batch.DatasetOutputCommitter
-
Called if the job failed.
- onFailure(WorkflowSpecification, Throwable) - Method in interface io.cdap.cdap.api.workflow.WorkflowCompletion
-
- onFinish(List<? extends Partition>, boolean) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.AbstractPartitionConsumer
-
- onFinish(boolean) - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.PartitionBatchInput.BatchPartitionCommitter
-
- onFinish(List<? extends Partition>, boolean) - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.PartitionConsumer
-
This method must be called on any partitions returned by the #consumePartitions
method.
- onFinish(List<? extends Partition>, boolean) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.TransactionalPartitionConsumer
-
- onFinish(HttpServiceResponder) - Method in class io.cdap.cdap.api.service.http.HttpContentConsumer
-
This method is invoked when the end of the request body is reached.
- onFinish() - Method in class io.cdap.cdap.api.service.http.HttpContentProducer
-
This method will get invoked after the last chunk of data is sent.
- onFinishWithKeys(List<? extends PartitionKey>, boolean) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.AbstractPartitionConsumer
-
- onFinishWithKeys(List<? extends PartitionKey>, boolean) - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.PartitionConsumer
-
- onFinishWithKeys(List<? extends PartitionKey>, boolean) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.TransactionalPartitionConsumer
-
- onMethodEntry(boolean, Class<? extends Annotation>) - Method in class io.cdap.cdap.internal.dataset.DatasetRuntimeContext
-
Method to call when a dataset method is invoked.
- onMethodExit() - Method in class io.cdap.cdap.internal.dataset.DatasetRuntimeContext
-
Method to call when a dataset method is about to return.
- onPartitions(String, int) - Method in interface io.cdap.cdap.api.schedule.TriggerFactory
-
Creates a trigger which is satisfied whenever at least a certain number of new partitions
are added to a certain dataset in the same namespace as the app.
- onPartitions(String, String, int) - Method in interface io.cdap.cdap.api.schedule.TriggerFactory
-
Creates a trigger which is satisfied whenever at least a certain number of new partitions
are added to a certain dataset in the specified namespace.
- onProgramStatus(String, String, String, ProgramType, String, ProgramStatus...) - Method in interface io.cdap.cdap.api.schedule.TriggerFactory
-
Creates a trigger which is satisfied when the given program in the given namespace, application, and
application version transitions to any one of the given program statuses.
- onProgramStatus(String, String, ProgramType, String, ProgramStatus...) - Method in interface io.cdap.cdap.api.schedule.TriggerFactory
-
Creates a trigger which is satisfied when the given program in the given namespace
and application with default version transitions to any one of the given program statuses.
- onProgramStatus(String, ProgramType, String, ProgramStatus...) - Method in interface io.cdap.cdap.api.schedule.TriggerFactory
-
Creates a trigger which is satisfied when the given program in the given application in the same namespace
transitions to any one of the given program statuses.
- onProgramStatus(ProgramType, String, ProgramStatus...) - Method in interface io.cdap.cdap.api.schedule.TriggerFactory
-
Creates a trigger which is satisfied when the given program in the same namespace, application,
and application version transitions to any one of the given program statuses.
- onReceived(ByteBuffer, Transactional) - Method in class io.cdap.cdap.api.service.http.HttpContentConsumer
-
This method is invoked when a new chunk of the request body is available to be consumed.
- onSuccess() - Method in interface io.cdap.cdap.api.data.batch.DatasetOutputCommitter
-
Called if the job completed successfully.
- onSuccess(WorkflowSpecification) - Method in interface io.cdap.cdap.api.workflow.WorkflowCompletion
-
- openConnection(String, String, String, String) - Method in interface io.cdap.cdap.api.ServiceDiscoverer
-
- Operation - Class in io.cdap.cdap.api.lineage.field
-
Abstract base class to represent an Operation.
- Operation(String, OperationType, String) - Constructor for class io.cdap.cdap.api.lineage.field.Operation
-
- OperationType - Enum in io.cdap.cdap.api.lineage.field
-
Represents operation types.
- OptionsSetter<T> - Interface in io.cdap.cdap.api.builder
-
- or(Trigger...) - Method in interface io.cdap.cdap.api.schedule.TriggerFactory
-
Creates a trigger which is satisfied when at least one of the internal triggers are satisfied.
- otherwise() - Method in interface io.cdap.cdap.api.workflow.WorkflowConditionConfigurer
-
- Output - Class in io.cdap.cdap.api.data.batch
-
Defines output of a program, such as MapReduce.
- Output.DatasetOutput - Class in io.cdap.cdap.api.data.batch
-
An implementation of
Output
, which defines a
Dataset
as an output.
- Output.OutputFormatProviderOutput - Class in io.cdap.cdap.api.data.batch
-
- OUTPUT_FORMAT - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
The name of the output format class.
- OUTPUT_PARTITION_KEY_PREFIX - Static variable in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
- OUTPUT_PARTITION_METADATA_PREFIX - Static variable in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
- OUTPUT_PARTITION_TIME - Static variable in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
- OUTPUT_PATH - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetArguments
-
The path of the file to write.
- OUTPUT_PATH_FORMAT - Static variable in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
- OUTPUT_PROPERTIES_PREFIX - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
Prefix for additional properties for the output format.
- OUTPUT_TIME_ZONE - Static variable in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
- OutputFormatProvider - Interface in io.cdap.cdap.api.data.batch
-
Interface to be implemented by datasets used as output of a MapReduce.
- Parameter - Class in io.cdap.cdap.internal.guava.reflect
-
Represents a method or constructor parameter.
- parse(String) - Static method in class io.cdap.cdap.api.artifact.ArtifactVersionRange
-
- parse(String) - Method in enum io.cdap.cdap.api.dataset.lib.Partitioning.FieldType
-
Parse a string into a value of this field type.
- Partition - Interface in io.cdap.cdap.api.dataset.lib
-
Represents a partition of a partitioned file set.
- PartitionAcceptor - Interface in io.cdap.cdap.api.dataset.lib.partitioned
-
Defines whether to accept
PartitionDetail
s, while iterating over a collection of them.
- PartitionAcceptor.Limit - Class in io.cdap.cdap.api.dataset.lib.partitioned
-
An implementation of PartitionAcceptor which limits the number of accepted partitions to a given value.
- PartitionAcceptor.Return - Enum in io.cdap.cdap.api.dataset.lib.partitioned
-
Return value, determining what to do with a Partition.
- PartitionAlreadyExistsException - Exception in io.cdap.cdap.api.dataset.lib
-
Thrown when a Partition already exists.
- PartitionAlreadyExistsException(String, PartitionKey) - Constructor for exception io.cdap.cdap.api.dataset.lib.PartitionAlreadyExistsException
-
- PartitionBatchInput - Class in io.cdap.cdap.api.dataset.lib.partitioned
-
A utility class for batch processing (i.e.
- PartitionBatchInput() - Constructor for class io.cdap.cdap.api.dataset.lib.partitioned.PartitionBatchInput
-
- PartitionBatchInput.BatchPartitionCommitter - Interface in io.cdap.cdap.api.dataset.lib.partitioned
-
Used to persist the state of the partition consumer.
- PartitionConsumer - Interface in io.cdap.cdap.api.dataset.lib.partitioned
-
- PartitionConsumerResult - Class in io.cdap.cdap.api.dataset.lib
-
Returns access to an iterator of the requested partitions as well as a
PartitionConsumerState
which can be
used to request partitions created after the previous request of partitions.
- PartitionConsumerResult(PartitionConsumerState, List<PartitionDetail>) - Constructor for class io.cdap.cdap.api.dataset.lib.PartitionConsumerResult
-
- PartitionConsumerResult - Class in io.cdap.cdap.api.dataset.lib.partitioned
-
Returns access to a list of partitions for consuming, as well as a list of
PartitionKey
s corresponding
to partitions that have previously failed processing the configured number of tries.
- PartitionConsumerResult(List<PartitionDetail>, List<PartitionDetail>) - Constructor for class io.cdap.cdap.api.dataset.lib.partitioned.PartitionConsumerResult
-
- PartitionConsumerState - Class in io.cdap.cdap.api.dataset.lib
-
Contains the state necessary to keep track of which partitions are processed and which partitions would need to be
processed as they are created.
- PartitionConsumerState(long, List<Long>) - Constructor for class io.cdap.cdap.api.dataset.lib.PartitionConsumerState
-
- PartitionDetail - Interface in io.cdap.cdap.api.dataset.lib
-
Represents a partition of a partitioned file set, having metadata associated with it.
- PartitionedFileSet - Interface in io.cdap.cdap.api.dataset.lib
-
Represents a dataset that is split into partitions that can be uniquely addressed
by partition keys along multiple dimensions.
- PartitionedFileSetArguments - Class in io.cdap.cdap.api.dataset.lib
-
Helpers for manipulating runtime arguments of time-partitioned file sets.
- PartitionedFileSetArguments() - Constructor for class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
- PartitionedFileSetInputContext - Interface in io.cdap.cdap.api.data.batch
-
- PartitionedFileSetProperties - Class in io.cdap.cdap.api.dataset.lib
-
Helper to build properties for files datasets.
- PartitionedFileSetProperties() - Constructor for class io.cdap.cdap.api.dataset.lib.PartitionedFileSetProperties
-
- PartitionedFileSetProperties.Builder - Class in io.cdap.cdap.api.dataset.lib
-
A Builder to construct properties for FileSet datasets.
- PartitionExploreCorrector - Class in io.cdap.cdap.api.dataset.lib.app.partitioned
-
An application that can be used to bring the Explore state of a (Time)PartitionedFileSet in sync with
the actual partitions of the dataset.
- PartitionExploreCorrector() - Constructor for class io.cdap.cdap.api.dataset.lib.app.partitioned.PartitionExploreCorrector
-
- PartitionExploreCorrector.PartitionWorker - Class in io.cdap.cdap.api.dataset.lib.app.partitioned
-
This worker can be used to bring a partitioned file set in sync with Explore.
- PartitionFilter - Class in io.cdap.cdap.api.dataset.lib
-
Describes a filter over partition keys.
- PartitionFilter.Builder - Class in io.cdap.cdap.api.dataset.lib
-
A builder for partition filters.
- PartitionFilter.Condition<T extends Comparable<T>> - Class in io.cdap.cdap.api.dataset.lib
-
Represents a condition on a partitioning field, by means of an inclusive lower bound and an exclusive upper bound.
- Partitioning - Class in io.cdap.cdap.api.dataset.lib
-
This class describes how a dataset is partitioned, by means of the fields of a partition key and their types.
- Partitioning.Builder - Class in io.cdap.cdap.api.dataset.lib
-
A builder for partitioning objects.
- Partitioning.FieldType - Enum in io.cdap.cdap.api.dataset.lib
-
Describes the type of a partitioning field.
- PARTITIONING_FIELD_PREFIX - Static variable in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetProperties
-
The prefix for fields of the partitioning.
- PARTITIONING_FIELDS - Static variable in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetProperties
-
The property name for the list of partitioning field names.
- PartitionKey - Class in io.cdap.cdap.api.dataset.lib
-
Types and methods to specify partitioning keys for datasets.
- PartitionKey.Builder - Class in io.cdap.cdap.api.dataset.lib
-
A builder for partitioning objects.
- PartitionKeyCodec - Class in io.cdap.cdap.api.dataset.lib.partitioned
-
- PartitionKeyCodec() - Constructor for class io.cdap.cdap.api.dataset.lib.partitioned.PartitionKeyCodec
-
- PartitionMetadata - Class in io.cdap.cdap.api.dataset.lib
-
- PartitionMetadata(Map<String, String>, long, long) - Constructor for class io.cdap.cdap.api.dataset.lib.PartitionMetadata
-
- PartitionNotFoundException - Exception in io.cdap.cdap.api.dataset
-
Thrown when a
Partition
is not found on a PartitionedFileSet.
- PartitionNotFoundException(PartitionKey, String) - Constructor for exception io.cdap.cdap.api.dataset.PartitionNotFoundException
-
- PartitionOutput - Interface in io.cdap.cdap.api.dataset.lib
-
Represents a partition of a partitioned file set for writing.
- PartitionTriggerInfo - Interface in io.cdap.cdap.api.schedule
-
The dataset partition trigger information to be passed to the triggered program.
- PartitionWorker() - Constructor for class io.cdap.cdap.api.dataset.lib.app.partitioned.PartitionExploreCorrector.PartitionWorker
-
- persistState(DatasetContext, byte[]) - Method in interface io.cdap.cdap.api.dataset.lib.DatasetStatePersistor
-
Writes the serialized bytes of the state of the partition consuming process.
- persistState(byte[]) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.DelegatingStatePersistor
-
- persistState(DatasetContext, byte[]) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.KVTableStatePersistor
-
- persistState(byte[]) - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.StatePersistor
-
Writes the serialized bytes of the state of the partition consuming process.
- PlatformInfo - Class in io.cdap.cdap.api
-
Accessor class for providing project information.
- PlatformInfo.Version - Class in io.cdap.cdap.api
-
This class encapsulates information about project version.
- Plugin - Annotation Type in io.cdap.cdap.api.annotation
-
Annotate a class that it is a plugin.
- PLUGIN - Static variable in class io.cdap.cdap.api.metadata.MetadataEntity
-
- Plugin - Class in io.cdap.cdap.api.plugin
-
A container class for holding plugin information.
- Plugin(Iterable<ArtifactId>, ArtifactId, PluginClass, PluginProperties) - Constructor for class io.cdap.cdap.api.plugin.Plugin
-
Create a Plugin
- PluginClass - Class in io.cdap.cdap.api.plugin
-
Contains information about a plugin class.
- PluginClass(String, String, String, String, Map<String, PluginPropertyField>, Requirements, String) - Constructor for class io.cdap.cdap.api.plugin.PluginClass
-
- PluginClass(String, String, String, String, String, Map<String, PluginPropertyField>) - Constructor for class io.cdap.cdap.api.plugin.PluginClass
-
- PluginClass.Builder - Class in io.cdap.cdap.api.plugin
-
- PluginConfig - Class in io.cdap.cdap.api.plugin
-
Base class for writing configuration class for template plugin.
- PluginConfig() - Constructor for class io.cdap.cdap.api.plugin.PluginConfig
-
- PluginConfigurer - Interface in io.cdap.cdap.api.plugin
-
This interface provides methods to register plugin usage in a CDAP Program.
- PluginContext - Interface in io.cdap.cdap.api.plugin
-
Provides access to plugin context when a program is executing.
- PluginProperties - Class in io.cdap.cdap.api.plugin
-
Plugin instance properties.
- PluginProperties.Builder - Class in io.cdap.cdap.api.plugin
-
- PluginPropertyField - Class in io.cdap.cdap.api.plugin
-
Contains information about a property used by a plugin.
- PluginPropertyField(String, String, String, boolean, boolean, boolean, Set<String>) - Constructor for class io.cdap.cdap.api.plugin.PluginPropertyField
-
- PluginPropertyField(String, String, String, boolean, boolean) - Constructor for class io.cdap.cdap.api.plugin.PluginPropertyField
-
- PluginPropertyField(String, String, String, boolean, boolean, boolean) - Constructor for class io.cdap.cdap.api.plugin.PluginPropertyField
-
- PluginSelector - Class in io.cdap.cdap.api.plugin
-
Represents a class for selecting a plugin.
- PluginSelector() - Constructor for class io.cdap.cdap.api.plugin.PluginSelector
-
- populate(PartitionedFileSet, ConsumerConfiguration) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerWorkingSet
-
Populates the ConsumerWorkingSet by fetching partitions from the given PartitionedFileSet.
- postTxCommit() - Method in class io.cdap.cdap.api.dataset.lib.AbstractDataset
-
- Predicate<T> - Interface in io.cdap.cdap.api
-
Determines a true or false value for a given input.
- ProcessState - Enum in io.cdap.cdap.api.dataset.lib.partitioned
-
Represents the process/consumed state of the partition.
- PROGRAM - Static variable in class io.cdap.cdap.api.metadata.MetadataEntity
-
- PROGRAM_NOT_FOUND - Static variable in class io.cdap.cdap.internal.UserErrors
-
- PROGRAM_RUN - Static variable in class io.cdap.cdap.api.metadata.MetadataEntity
-
- ProgramConfigurer - Interface in io.cdap.cdap.api
-
Basic Program Configurer.
- ProgramLifecycle<T extends RuntimeContext> - Interface in io.cdap.cdap.api
-
Defines program lifecycle.
- ProgramSpecification - Interface in io.cdap.cdap.api
-
This interface provides for getting the name, class name, and description specifications of any type of program.
- ProgramState - Class in io.cdap.cdap.api
-
Class to represent the state of the program.
- ProgramState(ProgramStatus, String) - Constructor for class io.cdap.cdap.api.ProgramState
-
Creates a new instance.
- ProgramStatus - Enum in io.cdap.cdap.api
-
Represents the runtime status of program.
- ProgramStatusTriggerInfo - Interface in io.cdap.cdap.api.schedule
-
The program status trigger information to be passed to the triggered program.
- ProgramType - Enum in io.cdap.cdap.api.app
-
Defines types of programs supported by the system.
- propagate(TransactionFailureException, Class<X>) - Static method in class io.cdap.cdap.api.Transactionals
-
Propagates the given TransactionFailureException
.
- propagate(TransactionFailureException, Class<X1>, Class<X2>) - Static method in class io.cdap.cdap.api.Transactionals
-
Propagates the given TransactionFailureException
.
- properties(Map<String, String>) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification.Builder
-
Add properties.
- propertiesWithPrefix(Map<String, String>, String) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
- Property - Annotation Type in io.cdap.cdap.api.annotation
-
Annotates fields that need to be captured at deployment time and restored at runtime.
- property(String, String) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification.Builder
-
Add a custom property.
- PROPERTY_COLUMN_FAMILY - Static variable in interface io.cdap.cdap.api.dataset.table.Table
-
Property set to configure name of the column family.
- PROPERTY_CONFLICT_LEVEL - Static variable in interface io.cdap.cdap.api.dataset.table.Table
-
Property set to configure transaction conflict detection level.
- PROPERTY_ENABLE_EXPLORE_ON_CREATE - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
Whether this dataset should be enabled for explore.
- PROPERTY_EXPLORE_DATABASE_NAME - Static variable in class io.cdap.cdap.api.dataset.ExploreProperties
-
Property to configure the name of the Explore database for a dataset; that is, the database in the external
system that implements Explore, such as Hive.
- PROPERTY_EXPLORE_FORMAT - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
The format to use for the explore table.
- PROPERTY_EXPLORE_INPUT_FORMAT - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
The input format to use for the Hive table.
- PROPERTY_EXPLORE_OUTPUT_FORMAT - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
The output format to use for the Hive table.
- PROPERTY_EXPLORE_SCHEMA - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
The schema to use for the explore table.
- PROPERTY_EXPLORE_SERDE - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
The serde to use for the Hive table.
- PROPERTY_EXPLORE_TABLE_NAME - Static variable in class io.cdap.cdap.api.dataset.ExploreProperties
-
Property to configure the name of the Explore table for a dataset; that is, the table in the external
system that implements Explore, such as Hive.
- PROPERTY_EXPLORE_TABLE_PROPERTY_PREFIX - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
Prefix used to store additional table properties for Hive.
- PROPERTY_FILES_GROUP - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
The group name that the permission are assigned to.
- PROPERTY_FILES_PERMISSIONS - Static variable in class io.cdap.cdap.api.dataset.lib.FileSetProperties
-
The permissions for the dataset.
- PROPERTY_READLESS_INCREMENT - Static variable in interface io.cdap.cdap.api.dataset.table.Table
-
Property set to configure read-less increment support for a dataset.
- PROPERTY_RESOLUTIONS - Static variable in interface io.cdap.cdap.api.dataset.lib.cube.Cube
-
Property set to configure resolutions to aggregate for.
- PROPERTY_SCHEMA - Static variable in interface io.cdap.cdap.api.dataset.table.Table
-
Property set to configure schema for the table.
- PROPERTY_SCHEMA_ROW_FIELD - Static variable in interface io.cdap.cdap.api.dataset.table.Table
-
Property set to configure which field in the schema is the row key.
- PROPERTY_TABLE_PERMISSIONS - Static variable in class io.cdap.cdap.api.dataset.table.TableProperties
-
Set the ACLs that should be granted for this table.
- PROPERTY_TTL - Static variable in interface io.cdap.cdap.api.dataset.table.Table
-
Property set to configure time-to-live on data within this dataset.
- PropertyFieldExtractor - Class in io.cdap.cdap.internal.specification
-
- PropertyFieldExtractor(Map<String, String>) - Constructor for class io.cdap.cdap.internal.specification.PropertyFieldExtractor
-
- PropertyProvider - Interface in io.cdap.cdap.api.common
-
Represents classes that provides properties.
- pruneIndex(byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedObjectStore
-
Deletes an index that is no longer needed.
- publish(String, String, String...) - Method in interface io.cdap.cdap.api.messaging.MessagePublisher
-
Publishes messages to the given topic.
- publish(String, String, Charset, String...) - Method in interface io.cdap.cdap.api.messaging.MessagePublisher
-
Publishes messages to the given topic.
- publish(String, String, byte[]...) - Method in interface io.cdap.cdap.api.messaging.MessagePublisher
-
Publishes messages to the given topic.
- publish(String, String, Charset, Iterator<String>) - Method in interface io.cdap.cdap.api.messaging.MessagePublisher
-
Publishes messages to the given topic.
- publish(String, String, Iterator<byte[]>) - Method in interface io.cdap.cdap.api.messaging.MessagePublisher
-
Publishes messages to the given topic.
- put(Put) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Writes a put to the data table.
- put(byte[], byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- put(byte[], byte[][], byte[][]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- Put - Class in io.cdap.cdap.api.dataset.table
-
Writes the specified value(s) in one or more columns of a row -- this overrides existing values.
- Put(byte[]) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write to a row.
- Put(byte[], byte[], byte[]) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(byte[], byte[], String) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(byte[], byte[], boolean) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of row.
- Put(byte[], byte[], short) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(byte[], byte[], int) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(byte[], byte[], long) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(byte[], byte[], float) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(byte[], byte[], double) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(String) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write to a row.
- Put(String, String, byte[]) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(String, String, String) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(String, String, boolean) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(String, String, short) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(String, String, int) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(String, String, long) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(String, String, float) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of a row.
- Put(String, String, double) - Constructor for class io.cdap.cdap.api.dataset.table.Put
-
Write at least one value in a column of row.
- put(byte[], byte[], byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Writes the specified value for the specified column of the specified row.
- put(byte[], byte[][], byte[][]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Writes the specified values for the specified columns of the specified row.
- put(Put) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Writes values into a column of a row as defined by the
Put
parameter.
- put(String, String, String, String, Map<String, String>) - Method in interface io.cdap.cdap.api.security.store.SecureStoreManager
-
Stores an element in the secure store.
- put(String, String) - Method in interface io.cdap.cdap.api.workflow.WorkflowToken
-
- put(String, Value) - Method in interface io.cdap.cdap.api.workflow.WorkflowToken
-
- rawTypes() - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken.TypeSet
-
Returns the raw types of the types in this set, in the same order.
- read(byte[], long, long, byte[]...) - Method in class io.cdap.cdap.api.dataset.lib.CounterTimeseriesTable
-
Reads entries for a given time range and returns an Iterator
.
- read(byte[], long, long, int, int, byte[]...) - Method in class io.cdap.cdap.api.dataset.lib.CounterTimeseriesTable
-
Reads entries for a given time range and returns an Iterator
.
- read(byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedObjectStore
-
- read(String) - Method in class io.cdap.cdap.api.dataset.lib.IndexedObjectStore
-
- read(String) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
Read the value for a given key.
- read(byte[]) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
Read the value for a given key.
- read(String) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectMappedTable
-
Read an object with a given key.
- read(byte[]) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectMappedTable
-
Read an object with a given key.
- read(String) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectStore
-
Read an object with a given key.
- read(byte[]) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectStore
-
Read an object with a given key.
- read(byte[], long, long, int, int, byte[]...) - Method in class io.cdap.cdap.api.dataset.lib.TimeseriesTable
-
Reads entries for a given time range and returns an Iterator
.
- read(byte[], long, long, byte[]...) - Method in class io.cdap.cdap.api.dataset.lib.TimeseriesTable
-
Reads entries for a given time range and returns an Iterator
.
- readAll(byte[][]) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
Reads the values for an array of given keys.
- readAllByIndex(byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedObjectStore
-
Read all the objects from the objectStore for a given index.
- readByIndex(byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Reads table rows by the given secondary index key.
- readExternal(DataInput) - Method in class io.cdap.cdap.api.data.batch.SimpleSplit
-
- readExternal(DataInput) - Method in class io.cdap.cdap.api.data.batch.Split
-
Deserialize this split.
- readExternal(DataInput) - Method in class io.cdap.cdap.api.dataset.lib.TimeseriesTable.InputSplit
-
- readExternal(DataInput) - Method in class io.cdap.cdap.api.dataset.table.TableSplit
-
- ReadOnly - Annotation Type in io.cdap.cdap.api.annotation
-
Annotation to denote if a
Dataset
constructor or method only performs read operations.
- ReadOperation - Class in io.cdap.cdap.api.lineage.field
-
Represents a read operation from a data source into a collection of output fields.
- ReadOperation(String, String, EndPoint, String...) - Constructor for class io.cdap.cdap.api.lineage.field.ReadOperation
-
Create an instance of read operation.
- ReadOperation(String, String, EndPoint, List<String>) - Constructor for class io.cdap.cdap.api.lineage.field.ReadOperation
-
Create an instance of read operation.
- readState(DatasetContext) - Method in interface io.cdap.cdap.api.dataset.lib.DatasetStatePersistor
-
- readState() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.DelegatingStatePersistor
-
- readState(DatasetContext) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.KVTableStatePersistor
-
- readState() - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.StatePersistor
-
- ReadWrite - Annotation Type in io.cdap.cdap.api.annotation
-
Annotation to denote if a
Dataset
constructor or method performs both read and write operations.
- Reconfigurable - Interface in io.cdap.cdap.api.dataset
-
Interface implemented by DatasetDefinitions that have a way to reconfigure the dataset properties.
- reconfigure(DatasetDefinition, String, DatasetProperties, DatasetSpecification) - Static method in class io.cdap.cdap.api.dataset.lib.AbstractDatasetDefinition
-
Reconfigure a dataset instance.
- reconfigure(String, DatasetProperties, DatasetSpecification) - Method in class io.cdap.cdap.api.dataset.lib.CompositeDatasetDefinition
-
- reconfigure(String, DatasetProperties, DatasetSpecification) - Method in class io.cdap.cdap.api.dataset.lib.CounterTimeseriesTableDefinition
-
- reconfigure(String, DatasetProperties, DatasetSpecification) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTableDefinition
-
- reconfigure(String, DatasetProperties, DatasetSpecification) - Method in class io.cdap.cdap.api.dataset.lib.TimeseriesTableDefinition
-
- reconfigure(String, DatasetProperties, DatasetSpecification) - Method in interface io.cdap.cdap.api.dataset.Reconfigurable
-
Validates the new properties, including a compatibility check with the existing spec, and returns a
new dataset specification for the dataset instance.
- record(Collection<? extends Operation>) - Method in interface io.cdap.cdap.api.lineage.field.LineageRecorder
-
Record specified operations for the lineage purpose.
- RecordScannable<RECORD> - Interface in io.cdap.cdap.api.data.batch
-
Represents data sets that can be processed in batches, as series of records (as apposed to key/value pairs).
- RecordScanner<RECORD> - Class in io.cdap.cdap.api.data.batch
-
Defines a reader of a dataset
Split
.
- RecordScanner() - Constructor for class io.cdap.cdap.api.data.batch.RecordScanner
-
- RecordWritable<RECORD> - Interface in io.cdap.cdap.api.data.batch
-
Interface for a dataset that a batch job can output to, as series of records (as apposed to key/value pairs).
- Reflections - Class in io.cdap.cdap.internal.lang
-
Utility class for helper methods to deal with Java Reflection.
- ReflectionSchemaGenerator - Class in io.cdap.cdap.internal.io
-
This class uses Java Reflection to inspect fields in any Java class to generate RECORD schema.
- ReflectionSchemaGenerator(boolean) - Constructor for class io.cdap.cdap.internal.io.ReflectionSchemaGenerator
-
- ReflectionSchemaGenerator() - Constructor for class io.cdap.cdap.internal.io.ReflectionSchemaGenerator
-
- register(DatasetDefinitionRegistry) - Method in interface io.cdap.cdap.api.dataset.module.DatasetModule
-
Registers dataset types and other components in the system.
- releaseDataset(Dataset) - Method in interface io.cdap.cdap.api.data.DatasetContext
-
Calling this means that the dataset is not used by the caller any more,
and the DatasetContext is free to dismiss or reuse it.
- remove() - Method in class io.cdap.cdap.api.dataset.lib.AbstractCloseableIterator
-
- remove(PartitionKey) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerWorkingSet
-
- removeDiscardedPartitions(ConsumerWorkingSet) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConcurrentPartitionConsumer
-
Removes the list of partitions that have failed processing the configured number of times from the working set and
returns them.
- removeMetadata(PartitionKey, String) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Removes a metadata entry for a particular partition.
- removeMetadata(PartitionKey, Set<String>) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Removes a set of metadata entries for a particular partition.
- removeMetadata(long, String) - Method in interface io.cdap.cdap.api.dataset.lib.TimePartitionedFileSet
-
Removes a metadata entry for a particular time.
- removeMetadata(long, Set<String>) - Method in interface io.cdap.cdap.api.dataset.lib.TimePartitionedFileSet
-
Removes a set of metadata entries for a particular time.
- removeMetadata(MetadataEntity) - Method in interface io.cdap.cdap.api.metadata.MetadataWriter
-
Removes all the user metadata (including properties and tags) for the specified
MetadataEntity
.
- removeProperties(MetadataEntity) - Method in interface io.cdap.cdap.api.metadata.MetadataWriter
-
Removes all properties from the user metadata of the specified
MetadataEntity
.
- removeProperties(MetadataEntity, String...) - Method in interface io.cdap.cdap.api.metadata.MetadataWriter
-
Removes the specified keys from the user metadata properties of the specified
MetadataEntity
.
- removeTags(MetadataEntity) - Method in interface io.cdap.cdap.api.metadata.MetadataWriter
-
- removeTags(MetadataEntity, String...) - Method in interface io.cdap.cdap.api.metadata.MetadataWriter
-
- Requirements - Annotation Type in io.cdap.cdap.api.annotation
-
Annotates the requirements needed by a plugin to run successfully.
- Requirements - Class in io.cdap.cdap.api.plugin
-
A class to encapsulate all the different types of requirements provided by
Requirements
.
- Requirements(Set<String>) - Constructor for class io.cdap.cdap.api.plugin.Requirements
-
- Requirements(Set<String>, Set<String>) - Constructor for class io.cdap.cdap.api.plugin.Requirements
-
- resolution(long, TimeUnit) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeExploreQuery.Builder.From
-
- resolution(long, TimeUnit) - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery.Builder.From
-
- resolveType(Type) - Method in class io.cdap.cdap.internal.guava.reflect.TypeResolver
-
Resolves all type variables in type
and all downstream types and
returns a corresponding type with type variables resolved.
- resolveType(Type) - Method in class io.cdap.cdap.internal.guava.reflect.TypeToken
-
Resolves the given type
against the type context represented by this type.
- Resources - Class in io.cdap.cdap.api
-
Carries system resources requirements.
- Resources() - Constructor for class io.cdap.cdap.api.Resources
-
Constructs a Resources instance that represents 1 virtual core and 512MB of memory.
- Resources(int) - Constructor for class io.cdap.cdap.api.Resources
-
Constructs a Resources instance that represents 1 virtual core and custom memory size.
- Resources(int, int) - Constructor for class io.cdap.cdap.api.Resources
-
Constructs a Resources instance.
- Result - Class in io.cdap.cdap.api.dataset.table
-
Default implementation of
Row
- Result(byte[], Map<byte[], byte[]>) - Constructor for class io.cdap.cdap.api.dataset.table.Result
-
- RetriesExhaustedException - Exception in io.cdap.cdap.api.retry
-
An exception that indicates an operation failed after it was retried.
- RetriesExhaustedException(String, int) - Constructor for exception io.cdap.cdap.api.retry.RetriesExhaustedException
-
- RetriesExhaustedException(String) - Constructor for exception io.cdap.cdap.api.retry.RetriesExhaustedException
-
- RetriesExhaustedException(Throwable) - Constructor for exception io.cdap.cdap.api.retry.RetriesExhaustedException
-
- RetriesExhaustedException(String, Throwable) - Constructor for exception io.cdap.cdap.api.retry.RetriesExhaustedException
-
- retry() - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.ConsumablePartition
-
Marks the ProcessState as AVAILABLE, resets the timestamp to 0, and increments the number of failures by 1
- retry() - Method in class io.cdap.cdap.api.dataset.lib.partitioned.DefaultConsumablePartition
-
- RetryableException - Exception in io.cdap.cdap.api.retry
-
An exception that indicates an operation failed in a retryable way.
- RetryableException() - Constructor for exception io.cdap.cdap.api.retry.RetryableException
-
- RetryableException(String) - Constructor for exception io.cdap.cdap.api.retry.RetryableException
-
- RetryableException(Throwable) - Constructor for exception io.cdap.cdap.api.retry.RetryableException
-
- RetryableException(String, Throwable) - Constructor for exception io.cdap.cdap.api.retry.RetryableException
-
- RetryCountProvider - Interface in io.cdap.cdap.api.retry
-
Retry count provider interface
- RetryFailedException - Exception in io.cdap.cdap.api.retry
-
Exception for retry failure.
- RetryFailedException(String, int) - Constructor for exception io.cdap.cdap.api.retry.RetryFailedException
-
- returning(Class<R1>) - Method in class io.cdap.cdap.internal.guava.reflect.Invokable
-
Explicitly specifies the return type of this Invokable
.
- returning(TypeToken<R1>) - Method in class io.cdap.cdap.internal.guava.reflect.Invokable
-
Explicitly specifies the return type of this Invokable
.
- rollbackTx() - Method in class io.cdap.cdap.api.dataset.lib.AbstractDataset
-
- Row - Interface in io.cdap.cdap.api.dataset.table
-
Represents one row in a table with a subset of columns.
- ROW_KEY_EXPLORE_NAME - Static variable in class io.cdap.cdap.api.dataset.lib.ObjectMappedTableProperties
-
The name of the Hive table column for the key of objects stored in the table.
- ROW_KEY_EXPLORE_TYPE - Static variable in class io.cdap.cdap.api.dataset.lib.ObjectMappedTableProperties
-
The type of the Hive table column for the row key of objects stored in the table.
- RowColumns<T> - Class in io.cdap.cdap.api.dataset.table
-
Base class for defining a row with set of columns.
- RowColumns(byte[]) - Constructor for class io.cdap.cdap.api.dataset.table.RowColumns
-
Defines a row with all columns included.
- RowColumns(byte[], byte[]...) - Constructor for class io.cdap.cdap.api.dataset.table.RowColumns
-
Defines a row, with the specified set of columns.
- RowColumns(String) - Constructor for class io.cdap.cdap.api.dataset.table.RowColumns
-
Defines a row with all columns included.
- RowColumns(String, String...) - Constructor for class io.cdap.cdap.api.dataset.table.RowColumns
-
Defines a row, including all columns, unless additional columns are specified.
- run() - Method in interface io.cdap.cdap.api.customaction.CustomAction
-
Implementation should contain the code that will be executed by Workflow at runtime.
- run() - Method in class io.cdap.cdap.api.dataset.lib.app.partitioned.PartitionExploreCorrector.PartitionWorker
-
- run(DatasetContext) - Method in interface io.cdap.cdap.api.TxRunnable
-
- RUNTIME_INFO_NOT_FOUND - Static variable in class io.cdap.cdap.internal.UserErrors
-
- RuntimeArguments - Class in io.cdap.cdap.api.common
-
Utility class for manipulating runtime arguments.
- RuntimeContext - Interface in io.cdap.cdap.api
-
This interface represents a context for a processor or elements of a processor.
- RuntimeMetrics - Interface in io.cdap.cdap.api.metrics
-
Provides access to metrics about processors.
- scan(byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- scan(Scan) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
- scan(byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.lib.KeyValueTable
-
Scans table.
- scan(String, String) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectMappedTable
-
Scans table.
- scan(byte[], byte[]) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectMappedTable
-
Scans table.
- scan(Scan) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectMappedTable
-
Scans table.
- scan(byte[], byte[]) - Method in interface io.cdap.cdap.api.dataset.lib.ObjectStore
-
Scans table.
- Scan - Class in io.cdap.cdap.api.dataset.table
-
Scan configuration for
Table
.
- Scan(byte[], byte[]) - Constructor for class io.cdap.cdap.api.dataset.table.Scan
-
Creates
Scan
for a given start and stop row keys.
- Scan(byte[], byte[], Filter) - Constructor for class io.cdap.cdap.api.dataset.table.Scan
-
Creates
Scan
for a given start and stop row keys and filter.
- scan(byte[], byte[]) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
Scans table.
- scan(Scan) - Method in interface io.cdap.cdap.api.dataset.table.Table
-
- scanByIndex(byte[], byte[], byte[]) - Method in class io.cdap.cdap.api.dataset.lib.IndexedTable
-
Reads table rows within the given secondary index key range.
- Scannables - Class in io.cdap.cdap.api.data.batch
-
Utility methods for record scanners.
- Scannables() - Constructor for class io.cdap.cdap.api.data.batch.Scannables
-
- Scannables.RecordMaker<KEY,VALUE,RECORD> - Interface in io.cdap.cdap.api.data.batch
-
Provides a way to convert a key and a value - as provided by a split reader - in to a single record object.
- Scanner - Interface in io.cdap.cdap.api.dataset.table
-
Interface for table scan operation.
- SchedulableProgramContext - Interface in io.cdap.cdap.api
-
This interface provides the context for accessing scheduling information of this program.
- SchedulableProgramType - Enum in io.cdap.cdap.api.schedule
-
Defines types of programs that can be scheduled by the Application.
- schedule(ScheduleCreationSpec) - Method in class io.cdap.cdap.api.app.AbstractApplication
-
Schedules a program, using the given scheduleCreationSpec.
- schedule(ScheduleCreationSpec) - Method in interface io.cdap.cdap.api.app.ApplicationConfigurer
-
Schedules a program, using the given scheduleCreationSpec.
- SCHEDULE - Static variable in class io.cdap.cdap.api.metadata.MetadataEntity
-
- ScheduleBuilder - Interface in io.cdap.cdap.api.schedule
-
Builder for scheduling a program.
- ScheduleCreationSpec - Class in io.cdap.cdap.internal.schedule
-
Information for creating a program schedule.
- ScheduleCreationSpec(String, String, String, Map<String, String>, Trigger, List<? extends Constraint>, long) - Constructor for class io.cdap.cdap.internal.schedule.ScheduleCreationSpec
-
- ScheduleProgramInfo - Class in io.cdap.cdap.api.workflow
-
Represents name and type information of the program.
- ScheduleProgramInfo(SchedulableProgramType, String) - Constructor for class io.cdap.cdap.api.workflow.ScheduleProgramInfo
-
- SCHEMA - Static variable in class io.cdap.cdap.api.dataset.DatasetProperties
-
Schema property.
- SchemaGenerator - Interface in io.cdap.cdap.internal.io
-
Interface for generating data
Schema
.
- scope - Variable in class io.cdap.cdap.api.artifact.ArtifactSummary
-
- Scope - Enum in io.cdap.cdap.api.common
-
Enum for the different types of scopes.
- scopeFor(String) - Static method in enum io.cdap.cdap.api.common.Scope
-
- searchDimensionValue(HttpServiceRequest, HttpServiceResponder) - Method in class io.cdap.cdap.api.dataset.lib.cube.AbstractCubeHttpHandler
-
- searchMeasure(HttpServiceRequest, HttpServiceResponder) - Method in class io.cdap.cdap.api.dataset.lib.cube.AbstractCubeHttpHandler
-
- SecureStore - Interface in io.cdap.cdap.api.security.store
-
Provides read access to the secure store.
- SecureStoreData - Class in io.cdap.cdap.api.security.store
-
This represents the entity stored in the Secure Store.
- SecureStoreData(SecureStoreMetadata, byte[]) - Constructor for class io.cdap.cdap.api.security.store.SecureStoreData
-
- SecureStoreManager - Interface in io.cdap.cdap.api.security.store
-
Provides write access to the secure store.
- SecureStoreMetadata - Class in io.cdap.cdap.api.security.store
-
Represents the metadata for the data stored in the Secure Store.
- SecureStoreMetadata(String, String, long, Map<String, String>) - Constructor for class io.cdap.cdap.api.security.store.SecureStoreMetadata
-
- select() - Method in class io.cdap.cdap.api.dataset.lib.cube.CubeQuery.Builder
-
- select(SortedMap<ArtifactId, PluginClass>) - Method in class io.cdap.cdap.api.plugin.PluginSelector
-
Selects a plugin.
- send(int, ByteBuffer, String, Map<String, String>) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends response back to client.
- send(int, ByteBuffer, String, Iterable<? extends Map.Entry<String, String>>) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends response back to client.
- send(int, HttpContentProducer, String) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
- send(int, HttpContentProducer, String, Map<String, String>) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
- send(int, HttpContentProducer, String, Iterable<? extends Map.Entry<String, String>>) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
- send(int, Location, String) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends response back to client using content in the given Location
as the response body.
- send(int, Location, String, Map<String, String>) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends response back to client using content in the given Location
as the response body.
- send(int, Location, String, Iterable<? extends Map.Entry<String, String>>) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends response back to client using content in the given Location
as the response body.
- sendError(int, String) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends an error message back to the client with the specified status code.
- sendJson(Object) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends JSON response back to the client with a default status.
- sendJson(int, Object) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends JSON response back to the client.
- sendJson(int, Object, Type, Gson) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends JSON response back to the client using the given Gson
object.
- sendStatus(int) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends only a status code back to client without any content.
- sendStatus(int, Map<String, String>) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends a status code and headers back to client without any content.
- sendStatus(int, Iterable<? extends Map.Entry<String, String>>) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends a status code and headers back to client without any content.
- sendString(String) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends a UTF-8 encoded string response back to the HTTP client with a default response status.
- sendString(int, String, Charset) - Method in interface io.cdap.cdap.api.service.http.HttpServiceResponder
-
Sends a string response back to the HTTP client.
- serialize(Split, DataOutput) - Static method in class io.cdap.cdap.api.data.batch.Splits
-
Serialize a
Split
instance.
- serialize(PartitionFilter.Condition, Type, JsonSerializationContext) - Method in class io.cdap.cdap.api.dataset.lib.ConditionCodec
-
- serialize(PartitionKey, Type, JsonSerializationContext) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.PartitionKeyCodec
-
- serializeComparable(Comparable, JsonSerializationContext) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ComparableCodec
-
- Service<T extends ServiceConfigurer,V extends ServiceContext> - Interface in io.cdap.cdap.api.service
-
Defines a custom user Service.
- ServiceConfigurer - Interface in io.cdap.cdap.api.service
-
Interface for configurers used to create custom Services.
- ServiceContext - Interface in io.cdap.cdap.api.service
-
- ServiceDiscoverer - Interface in io.cdap.cdap.api
-
An interface for Discovery Service.
- ServiceHttpEndpoint - Class in io.cdap.cdap.api.service.http
-
Describes an endpoint that a
Service
exposes.
- ServiceHttpEndpoint(String, String) - Constructor for class io.cdap.cdap.api.service.http.ServiceHttpEndpoint
-
- ServicePluginConfigurer - Interface in io.cdap.cdap.api.service.http
-
Plugin configurer specifically for service.
- ServiceSpecification - Class in io.cdap.cdap.api.service
-
- ServiceSpecification(String, String, String, Map<String, HttpServiceHandlerSpecification>, Resources, int, Map<String, Plugin>) - Constructor for class io.cdap.cdap.api.service.ServiceSpecification
-
- ServiceSpecification(String, String, String, Map<String, HttpServiceHandlerSpecification>, Resources, int, Map<String, Plugin>, Map<String, String>) - Constructor for class io.cdap.cdap.api.service.ServiceSpecification
-
- set(String, String) - Method in class io.cdap.cdap.api.data.batch.SimpleSplit
-
Sets an attribute.
- set(byte[], long, long, byte[]...) - Method in class io.cdap.cdap.api.dataset.lib.CounterTimeseriesTable
-
Set the value for a counter.
- set(Object, T) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- set(Object, T) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- setBaseOutputPath(Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetArguments
-
Sets the baseLocation of the file dataset as the output location in the runtime arguments for a file dataset.
- setBasePath(String) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Sets the base path for the file dataset.
- setBoolean(Object, boolean) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- setBoolean(Object, boolean) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- setByte(Object, byte) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- setByte(Object, byte) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- setCategory(String) - Method in class io.cdap.cdap.api.plugin.PluginClass.Builder
-
Set the plugin category
- setChar(Object, char) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- setChar(Object, char) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- setClassLoader(ClassLoader) - Method in class io.cdap.cdap.internal.io.TypeRepresentation
-
Set the class loader to be used by toType(), getRawType(), etc.
- setClassName(String) - Method in class io.cdap.cdap.api.plugin.PluginClass.Builder
-
Set the plugin class name
- setClientResources(Resources) - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
Sets the resources requirement for the Spark client process.
- setClientResources(Resources) - Method in interface io.cdap.cdap.api.spark.SparkConfigurer
-
Sets the resources requirement for the Spark client process.
- setColumnFamily(String) - Method in class io.cdap.cdap.api.dataset.table.TableProperties.AbstractBuilder
-
Set the column family for a table.
- setColumnFamily(byte[]) - Method in class io.cdap.cdap.api.dataset.table.TableProperties.AbstractBuilder
-
Set the column family for a table.
- setColumnFamily(DatasetProperties.Builder, String) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
Set the column family in a table's dataset properties.
- setColumnFamily(DatasetProperties.Builder, byte[]) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
Set the column family in a table's dataset properties.
- setConfigFieldName(String) - Method in class io.cdap.cdap.api.plugin.PluginClass.Builder
-
Set the plugin config field
- setConflictDetection(ConflictDetection) - Method in class io.cdap.cdap.api.dataset.table.TableProperties.AbstractBuilder
-
Set the conflict detection level.
- setConflictDetection(DatasetProperties.Builder, ConflictDetection) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
Set a conflict detection level in dataset properties.
- setContext(DatasetRuntimeContext) - Static method in class io.cdap.cdap.internal.dataset.DatasetRuntimeContext
-
- setCurrentKeyValue(KEY, VALUE) - Method in class io.cdap.cdap.api.data.batch.SplitReaderBase
-
- setDataExternal(boolean) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Configures whether the files (the data) in this fileset are managed externally.
- setDescription(String) - Method in class io.cdap.cdap.api.app.AbstractApplication
-
- setDescription(String) - Method in interface io.cdap.cdap.api.app.ApplicationConfigurer
-
Sets the description of the Application.
- setDescription(String) - Method in interface io.cdap.cdap.api.builder.DescriptionSetter
-
- setDescription(String) - Method in class io.cdap.cdap.api.customaction.AbstractCustomAction
-
- setDescription(String) - Method in interface io.cdap.cdap.api.customaction.CustomActionConfigurer
-
- setDescription(String) - Method in class io.cdap.cdap.api.dataset.DatasetProperties.Builder
-
Sets description of the dataset
- setDescription(String) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification.Builder
-
Set the dataset description.
- setDescription(String) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
- setDescription(String) - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
- setDescription(String) - Method in class io.cdap.cdap.api.plugin.PluginClass.Builder
-
Set the plugin description
- setDescription(String) - Method in interface io.cdap.cdap.api.ProgramConfigurer
-
Sets the description of the program.
- setDescription(String) - Method in interface io.cdap.cdap.api.schedule.ScheduleBuilder
-
Set the description of the schedule.
- setDescription(String) - Method in class io.cdap.cdap.api.service.AbstractService
-
Set the description of the Service.
- setDescription(String) - Method in interface io.cdap.cdap.api.service.ServiceConfigurer
-
Set description of the Service.
- setDescription(String) - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
Sets the description of the
Spark
.
- setDescription(String) - Method in class io.cdap.cdap.api.worker.AbstractWorker
-
Set description of the
Worker
.
- setDescription(String) - Method in class io.cdap.cdap.api.workflow.AbstractCondition
-
- setDescription(String) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- setDouble(Object, double) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- setDouble(Object, double) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- setDriverResources(Resources) - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
Sets the resources requirement for the driver of the
MapReduce
.
- setDriverResources(Resources) - Method in interface io.cdap.cdap.api.mapreduce.MapReduceConfigurer
-
Sets the resources requirement for the driver of the MapReduce.
- setDriverResources(Resources) - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
Sets the resources requirement for the Spark driver process.
- setDriverResources(Resources) - Method in interface io.cdap.cdap.api.spark.SparkClientContext
-
Sets the resources requirement for the Spark driver process.
- setDriverResources(Resources) - Method in interface io.cdap.cdap.api.spark.SparkConfigurer
-
Sets the resources requirement for the Spark driver process.
- setDynamicPartitioner(Map<String, String>, Class<? extends DynamicPartitioner<K, V>>) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Sets a DynamicPartitioner class to be used during the output of a PartitionedFileSet.
- setDynamicPartitioner(Map<String, String>, Class<? extends DynamicPartitioner<K, V>>, DynamicPartitioner.PartitionWriteOption) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Sets a DynamicPartitioner class to be used during the output of a PartitionedFileSet.
- setDynamicPartitioner(Map<String, String>, String) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Sets a DynamicPartitioner class to be used during the output of a PartitionedFileSet.
- setDynamicPartitioner(Map<String, String>, String, DynamicPartitioner.PartitionWriteOption) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Sets a DynamicPartitioner class to be used during the output of a PartitionedFileSet.
- setDynamicPartitionerConcurrency(Map<String, String>, boolean) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Sets whether concurrent writers are allowed when using DynamicPartitioner.
- setEnableExploreOnCreate(boolean) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Enable explore for this dataset.
- setEscaping(boolean) - Method in class io.cdap.cdap.api.macro.MacroParserOptions.Builder
-
- setExecutorResources(Resources) - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
Sets the resources requirement for the Spark executor processes.
- setExecutorResources(Resources) - Method in interface io.cdap.cdap.api.spark.SparkClientContext
-
Sets the resources, such as memory and virtual cores, to use for each executor process for the Spark program.
- setExecutorResources(Resources) - Method in interface io.cdap.cdap.api.spark.SparkConfigurer
-
Sets the resources requirement for the Spark executor processes.
- setExploreDatabaseName(String) - Method in class io.cdap.cdap.api.dataset.ExploreProperties.AbstractBuilder
-
Set the name of the Explore database to be used for Explore.
- setExploreDatabaseName(DatasetProperties.Builder, String) - Static method in class io.cdap.cdap.api.dataset.ExploreProperties
-
Set the name of the Explore database to be used for Explore.
- setExploreFormat(String) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Set the format for the Hive table.
- setExploreFormatProperty(String, String) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Set a property for the table format.
- setExploreInputFormat(String) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Set the input format used to create the Hive table.
- setExploreInputFormat(Class<?>) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Set the input format used to create the Hive table.
- setExploreOutputFormat(String) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Set the output format used to create the Hive table.
- setExploreOutputFormat(Class<?>) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Set the output format used to create the Hive table.
- setExploreSchema(String) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Set the schema for the Hive table.
- setExploreTableName(String) - Method in class io.cdap.cdap.api.dataset.ExploreProperties.AbstractBuilder
-
Set the name of the Explore table to be used for Explore.
- setExploreTableName(DatasetProperties.Builder, String) - Static method in class io.cdap.cdap.api.dataset.ExploreProperties
-
Set the name of the Explore table to be used for Explore.
- setFileGroup(String) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Set the name of the group for files and directories
- setFilePermissions(String) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Set the default permissions for files and directories
- setFloat(Object, float) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- setFloat(Object, float) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- setFunctionWhitelist(Collection<String>) - Method in class io.cdap.cdap.api.macro.MacroParserOptions.Builder
-
- setFunctionWhitelist(String...) - Method in class io.cdap.cdap.api.macro.MacroParserOptions.Builder
-
- setInput(MapReduceContext, String, DatasetStatePersistor) - Static method in class io.cdap.cdap.api.dataset.lib.partitioned.PartitionBatchInput
-
- setInput(MapReduceContext, String, DatasetStatePersistor, ConsumerConfiguration) - Static method in class io.cdap.cdap.api.dataset.lib.partitioned.PartitionBatchInput
-
Used from the initialize method of the implementing batch job to configure as input a PartitionedFileSet that has
specified a set of
Partition
s of a
PartitionedFileSet
to be processed by the run of the batch job.
- setInputEndTime(Map<String, String>, long) - Static method in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
Set the end (exclusive) of the time range to be read as input.
- setInputFormat(Class<?>) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Sets the input format of the file dataset.
- setInputFormat(String) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Sets the input format of the file dataset.
- setInputPartitionFilter(Map<String, String>, PartitionFilter) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Set the partition filter for the input to be read.
- setInputPath(Map<String, String>, String) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetArguments
-
Sets the input path in the runtime arguments for a file dataset.
- setInputPaths(Map<String, String>, String) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetArguments
-
Sets multiple input paths in the runtime arguments for a file dataset.
- setInputPaths(Map<String, String>, Collection<String>) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetArguments
-
Sets multiple input paths in the runtime arguments for a file dataset.
- setInputProperty(String, String) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Sets a property for the input format of the file dataset.
- setInputStartTime(Map<String, String>, long) - Static method in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
Set the start (inclusive) of the time range to be read as input.
- setInstances(int) - Method in class io.cdap.cdap.api.service.AbstractService
-
Sets the number of instances needed for the server that runs all
HttpServiceHandler
s of this Service.
- setInstances(int) - Method in interface io.cdap.cdap.api.service.ServiceConfigurer
-
Sets the number of instances needed for the server that runs all
HttpServiceHandler
s of this Service.
- setInstances(int) - Method in class io.cdap.cdap.api.worker.AbstractWorker
-
Sets the number of instances needed for the
Worker
.
- setInstances(int) - Method in interface io.cdap.cdap.api.worker.WorkerConfigurer
-
Sets the number of instances needed for the
Worker
.
- setInt(Object, int) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- setInt(Object, int) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- setLong(Object, long) - Method in class io.cdap.cdap.internal.io.AbstractFieldAccessor
-
- setLong(Object, long) - Method in interface io.cdap.cdap.internal.io.FieldAccessor
-
- setMacros(Macros) - Method in class io.cdap.cdap.api.plugin.PluginProperties
-
Creates and returns a new instance of Plugin properties with current properties and the passed macros parameter.
- setMainClass(Class<?>) - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
Sets the job main class name in specification.
- setMainClassName(String) - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
Sets the Spark job main class name in specification.
- setMainClassName(String) - Method in interface io.cdap.cdap.api.spark.SparkConfigurer
-
Sets the Spark program class name in specification.
- setMapperResources(Resources) - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
Sets the resources requirement for Mapper task of the
MapReduce
.
- setMapperResources(Resources) - Method in interface io.cdap.cdap.api.mapreduce.MapReduceConfigurer
-
Sets the resources requirement for Mapper task of the
MapReduce
.
- setMapperResources(Resources) - Method in interface io.cdap.cdap.api.mapreduce.MapReduceContext
-
Overrides the resources, such as memory and virtual cores, to use for each mapper of this MapReduce job.
- setMaxRecurseDepth(int) - Method in class io.cdap.cdap.api.macro.MacroParserOptions.Builder
-
- setMaxRetries(int) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerConfiguration.Builder
-
Sets the number of retries of the ConsumerConfiguration.
- setMaxWorkingSetSize(int) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerConfiguration.Builder
-
Sets the maximum working set size of the ConsumerConfiguration.
- setMetadata(PartitionKey, Map<String, String>) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionedFileSet
-
Sets metadata entries for a particular partition.
- setMetadata(Map<String, String>) - Method in interface io.cdap.cdap.api.dataset.lib.PartitionOutput
-
Sets the metadata of a partition, when creating a new partition.
- setMetadata(long, Map<String, String>) - Method in interface io.cdap.cdap.api.dataset.lib.TimePartitionedFileSet
-
Sets metadata entries for a particular partition.
- setMetricsCollector(MetricsCollector) - Method in class io.cdap.cdap.api.dataset.lib.AbstractDataset
-
- setMetricsCollector(MetricsCollector) - Method in interface io.cdap.cdap.api.dataset.metrics.MeteredDataset
-
Sets data ops metrics collector
- setName(String) - Method in class io.cdap.cdap.api.app.AbstractApplication
-
- setName(String) - Method in interface io.cdap.cdap.api.app.ApplicationConfigurer
-
Sets the name of the Application.
- setName(String) - Method in interface io.cdap.cdap.api.builder.NameSetter
-
- setName(String) - Method in class io.cdap.cdap.api.customaction.AbstractCustomAction
-
- setName(String) - Method in interface io.cdap.cdap.api.customaction.CustomActionConfigurer
-
- setName(String) - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
- setName(String) - Method in class io.cdap.cdap.api.plugin.PluginClass.Builder
-
Set the plugin name
- setName(String) - Method in interface io.cdap.cdap.api.ProgramConfigurer
-
Sets the name of the program.
- setName(String) - Method in class io.cdap.cdap.api.service.AbstractService
-
Set the name for the Service.
- setName(String) - Method in interface io.cdap.cdap.api.service.ServiceConfigurer
-
Set name of the service.
- setName(String) - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
Sets the name of the
Spark
.
- setName(String) - Method in class io.cdap.cdap.api.worker.AbstractWorker
-
- setName(String) - Method in class io.cdap.cdap.api.workflow.AbstractCondition
-
- setName(String) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- setOriginalProperties(DatasetProperties) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
- setOriginalProperties(Map<String, String>) - Method in class io.cdap.cdap.api.dataset.DatasetSpecification
-
- setOutputFormat(Class<?>) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Sets the output format of the file dataset.
- setOutputFormat(String) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Sets the output format of the file dataset.
- setOutputPartitionKey(Map<String, String>, PartitionKey) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Set the partition key of the output partition when using PartitionedFileSet as an OutputFormatProvider.
- setOutputPartitionMetadata(Map<String, String>, Map<String, String>) - Static method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetArguments
-
Sets the metadata of the output partition with using PartitionedFileSet as an OutputFormatProvider.
- setOutputPartitionTime(Map<String, String>, long) - Static method in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
Set the time of the output partition when using TimePartitionedFileSet as an OutputFormatProvider.
- setOutputPath(Map<String, String>, String) - Static method in class io.cdap.cdap.api.dataset.lib.FileSetArguments
-
Sets the output path in the runtime arguments for a file dataset.
- setOutputPathFormat(Map<String, String>, String) - Static method in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
This is the file extension for each partition when using TimePartitionedFileSet as an OutputFormatProvider.
- setOutputPathFormat(Map<String, String>, String, String) - Static method in class io.cdap.cdap.api.dataset.lib.TimePartitionedFileSetArguments
-
This is the file extension for each partition when using TimePartitionedFileSet as an OutputFormatProvider.
- setOutputProperty(String, String) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Sets a property for the output format of the file dataset.
- setPartitioning(Partitioning) - Method in class io.cdap.cdap.api.dataset.lib.PartitionedFileSetProperties.Builder
-
Sets the base path for the file dataset.
- setPartitionPredicate(Predicate<PartitionDetail>) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.ConsumerConfiguration.Builder
-
Sets the Predicate of the ConsumerConfiguration.
- setPossessExisting(boolean) - Method in class io.cdap.cdap.api.dataset.lib.FileSetProperties.Builder
-
Configures whether the file set should take possession of an existing base location.
- setProcessState(ProcessState) - Method in interface io.cdap.cdap.api.dataset.lib.partitioned.ConsumablePartition
-
Sets a ProcessState to this ConsumablePartition
- setProcessState(ProcessState) - Method in class io.cdap.cdap.api.dataset.lib.partitioned.DefaultConsumablePartition
-
- setProperties(Map<String, String>) - Method in class io.cdap.cdap.api.customaction.AbstractCustomAction
-
- setProperties(Map<String, String>) - Method in interface io.cdap.cdap.api.customaction.CustomActionConfigurer
-
- setProperties(Map<String, String>) - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
- setProperties(Map<String, PluginPropertyField>) - Method in class io.cdap.cdap.api.plugin.PluginClass.Builder
-
Set and replace the plugin properties
- setProperties(Map<String, String>) - Method in interface io.cdap.cdap.api.ProgramConfigurer
-
Sets a set of properties that will be available through the Program specification's getProperties() method
at runtime.
- setProperties(Map<String, String>) - Method in interface io.cdap.cdap.api.schedule.ScheduleBuilder
-
Set properties of the schedule.
- setProperties(Map<String, String>) - Method in class io.cdap.cdap.api.service.AbstractService
-
- setProperties(Map<String, String>) - Method in class io.cdap.cdap.api.service.http.AbstractHttpServiceHandler
-
- setProperties(Map<String, String>) - Method in interface io.cdap.cdap.api.service.http.HttpServiceConfigurer
-
- setProperties(Map<String, String>) - Method in interface io.cdap.cdap.api.service.ServiceConfigurer
-
- setProperties(Map<String, String>) - Method in class io.cdap.cdap.api.spark.AbstractSpark
-
- setProperties(Map<String, String>) - Method in class io.cdap.cdap.api.worker.AbstractWorker
-
- setProperties(Map<String, String>) - Method in class io.cdap.cdap.api.workflow.AbstractCondition
-
- setProperties(Map<String, String>) - Method in class io.cdap.cdap.api.workflow.AbstractWorkflow
-
- setProperty(String, String) - Method in class io.cdap.cdap.api.dataset.table.Scan
-
Set a property for the Scan.
- setPySparkScript(String, URI...) - Method in interface io.cdap.cdap.api.spark.SparkClientContext
-
Sets a python script to run using PySpark.
- setPySparkScript(String, Iterable<URI>) - Method in interface io.cdap.cdap.api.spark.SparkClientContext
-
Sets a python script to run using PySpark.
- setPySparkScript(URI, URI...) - Method in interface io.cdap.cdap.api.spark.SparkClientContext
-
Sets a location that points to a python script to run using PySpark.
- setPySparkScript(URI, Iterable<URI>) - Method in interface io.cdap.cdap.api.spark.SparkClientContext
-
Sets a location that points to a python script to run using PySpark.
- setReadlessIncrementSupport(boolean) - Method in class io.cdap.cdap.api.dataset.table.TableProperties.AbstractBuilder
-
Configure read-less increment support.
- setReadlessIncrementSupport(DatasetProperties.Builder, boolean) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
Configure read-less increment support in a table's dataset properties.
- setReducerResources(Resources) - Method in class io.cdap.cdap.api.mapreduce.AbstractMapReduce
-
Sets the resources requirement for Reducer task of the
MapReduce
.
- setReducerResources(Resources) - Method in interface io.cdap.cdap.api.mapreduce.MapReduceConfigurer
-
Sets the resources requirement for Reducer task of the
MapReduce
.
- setReducerResources(Resources) - Method in interface io.cdap.cdap.api.mapreduce.MapReduceContext
-
Override the resources, such as memory and virtual cores, to use for each reducer of this MapReduce job.
- setRequirements(Requirements) - Method in class io.cdap.cdap.api.plugin.PluginClass.Builder
-
Set the plugin requirements
- setResources(Resources) - Method in class io.cdap.cdap.api.service.AbstractService
-
Sets the resources requirements for the server that runs all
HttpServiceHandler
s of this Service.
- setResources(Resources) - Method in interface io.cdap.cdap.api.service.ServiceConfigurer
-
Sets the resources requirements for the server that runs all
HttpServiceHandler
s of this Service.
- setResources(Resources) - Method in class io.cdap.cdap.api.worker.AbstractWorker
-
Sets the resources requirements for the
Worker
.
- setResources(Resources) - Method in interface io.cdap.cdap.api.worker.WorkerConfigurer
-
Sets the resources requirements for the the
Worker
.
- setRowFieldName(String) - Method in class io.cdap.cdap.api.dataset.table.TableProperties.AbstractBuilder
-
Configure which field in the schema is the row key.
- setRowFieldName(DatasetProperties.Builder, String) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
Configure which field in the schema is the row key.
- setRowKeyExploreName(String) - Method in class io.cdap.cdap.api.dataset.lib.ObjectMappedTableProperties.Builder
-
Sets the row key column name in the corresponding Hive table for an ObjectMappedTable.
- setRowKeyExploreType(Schema.Type) - Method in class io.cdap.cdap.api.dataset.lib.ObjectMappedTableProperties.Builder
-
Sets the column type for the row key column in the corresponding Hive table for an ObjectMappedTable.
- setSchema(Schema) - Method in class io.cdap.cdap.api.dataset.table.TableProperties.AbstractBuilder
-
Set the schema of a table.
- setSchema(DatasetProperties.Builder, Schema) - Static method in class io.cdap.cdap.api.dataset.table.TableProperties
-
Set the schema in a table's dataset properties.
- setSerDe(String) - Method in class io.cdap.cdap.api.dataset.lib.