@Generated("by gapic-generator-java")
Package com.google.cloud.dataproc.v1
The interfaces provided are listed below, along with usage samples.
======================= AutoscalingPolicyServiceClient =======================
Service Description: The API interface for managing autoscaling policies in the Dataproc API.
Sample for AutoscalingPolicyServiceClient:
// This snippet has been automatically generated and should be regarded as a code template only.
// It will require modifications to work:
// - It may require correct/in-range values for request initialization.
// - It may require specifying regional endpoints when creating the service client as shown in
// https://cloud.google.com/java/docs/setup#configure_endpoints_for_the_client_library
try (AutoscalingPolicyServiceClient autoscalingPolicyServiceClient =
AutoscalingPolicyServiceClient.create()) {
LocationName parent = LocationName.of("[PROJECT]", "[LOCATION]");
AutoscalingPolicy policy = AutoscalingPolicy.newBuilder().build();
AutoscalingPolicy response =
autoscalingPolicyServiceClient.createAutoscalingPolicy(parent, policy);
}
======================= BatchControllerClient =======================
Service Description: The BatchController provides methods to manage batch workloads.
Sample for BatchControllerClient:
// This snippet has been automatically generated and should be regarded as a code template only.
// It will require modifications to work:
// - It may require correct/in-range values for request initialization.
// - It may require specifying regional endpoints when creating the service client as shown in
// https://cloud.google.com/java/docs/setup#configure_endpoints_for_the_client_library
try (BatchControllerClient batchControllerClient = BatchControllerClient.create()) {
BatchName name = BatchName.of("[PROJECT]", "[LOCATION]", "[BATCH]");
Batch response = batchControllerClient.getBatch(name);
}
======================= ClusterControllerClient =======================
Service Description: The ClusterControllerService provides methods to manage clusters of Compute Engine instances.
Sample for ClusterControllerClient:
// This snippet has been automatically generated and should be regarded as a code template only.
// It will require modifications to work:
// - It may require correct/in-range values for request initialization.
// - It may require specifying regional endpoints when creating the service client as shown in
// https://cloud.google.com/java/docs/setup#configure_endpoints_for_the_client_library
try (ClusterControllerClient clusterControllerClient = ClusterControllerClient.create()) {
String projectId = "projectId-894832108";
String region = "region-934795532";
String clusterName = "clusterName-1141738587";
Cluster response = clusterControllerClient.getCluster(projectId, region, clusterName);
}
======================= JobControllerClient =======================
Service Description: The JobController provides methods to manage jobs.
Sample for JobControllerClient:
// This snippet has been automatically generated and should be regarded as a code template only.
// It will require modifications to work:
// - It may require correct/in-range values for request initialization.
// - It may require specifying regional endpoints when creating the service client as shown in
// https://cloud.google.com/java/docs/setup#configure_endpoints_for_the_client_library
try (JobControllerClient jobControllerClient = JobControllerClient.create()) {
String projectId = "projectId-894832108";
String region = "region-934795532";
Job job = Job.newBuilder().build();
Job response = jobControllerClient.submitJob(projectId, region, job);
}
======================= NodeGroupControllerClient =======================
Service Description: The `NodeGroupControllerService` provides methods to manage node groups of Compute Engine managed instances.
Sample for NodeGroupControllerClient:
// This snippet has been automatically generated and should be regarded as a code template only.
// It will require modifications to work:
// - It may require correct/in-range values for request initialization.
// - It may require specifying regional endpoints when creating the service client as shown in
// https://cloud.google.com/java/docs/setup#configure_endpoints_for_the_client_library
try (NodeGroupControllerClient nodeGroupControllerClient = NodeGroupControllerClient.create()) {
NodeGroupName name = NodeGroupName.of("[PROJECT]", "[REGION]", "[CLUSTER]", "[NODE_GROUP]");
NodeGroup response = nodeGroupControllerClient.getNodeGroup(name);
}
======================= WorkflowTemplateServiceClient =======================
Service Description: The API interface for managing Workflow Templates in the Dataproc API.
Sample for WorkflowTemplateServiceClient:
// This snippet has been automatically generated and should be regarded as a code template only.
// It will require modifications to work:
// - It may require correct/in-range values for request initialization.
// - It may require specifying regional endpoints when creating the service client as shown in
// https://cloud.google.com/java/docs/setup#configure_endpoints_for_the_client_library
try (WorkflowTemplateServiceClient workflowTemplateServiceClient =
WorkflowTemplateServiceClient.create()) {
LocationName parent = LocationName.of("[PROJECT]", "[LOCATION]");
WorkflowTemplate template = WorkflowTemplate.newBuilder().build();
WorkflowTemplate response =
workflowTemplateServiceClient.createWorkflowTemplate(parent, template);
}
-
Class Summary Class Description AcceleratorConfig Specifies the type and number of accelerator cards attached to the instances of an instance.AcceleratorConfig.Builder Specifies the type and number of accelerator cards attached to the instances of an instance.AutoscalingConfig Autoscaling Policy config associated with the cluster.AutoscalingConfig.Builder Autoscaling Policy config associated with the cluster.AutoscalingPoliciesProto AutoscalingPolicy Describes an autoscaling policy for Dataproc cluster autoscaler.AutoscalingPolicy.Builder Describes an autoscaling policy for Dataproc cluster autoscaler.AutoscalingPolicyName AutoscalingPolicyName.Builder Builder for projects/{project}/locations/{location}/autoscalingPolicies/{autoscaling_policy}.AutoscalingPolicyName.ProjectRegionAutoscalingPolicyBuilder Builder for projects/{project}/regions/{region}/autoscalingPolicies/{autoscaling_policy}.AutoscalingPolicyServiceClient Service Description: The API interface for managing autoscaling policies in the Dataproc API.AutoscalingPolicyServiceClient.ListAutoscalingPoliciesFixedSizeCollection AutoscalingPolicyServiceClient.ListAutoscalingPoliciesPage AutoscalingPolicyServiceClient.ListAutoscalingPoliciesPagedResponse AutoscalingPolicyServiceGrpc The API interface for managing autoscaling policies in the Dataproc API.AutoscalingPolicyServiceGrpc.AutoscalingPolicyServiceBlockingStub A stub to allow clients to do synchronous rpc calls to service AutoscalingPolicyService.AutoscalingPolicyServiceGrpc.AutoscalingPolicyServiceFutureStub A stub to allow clients to do ListenableFuture-style rpc calls to service AutoscalingPolicyService.AutoscalingPolicyServiceGrpc.AutoscalingPolicyServiceImplBase Base class for the server implementation of the service AutoscalingPolicyService.AutoscalingPolicyServiceGrpc.AutoscalingPolicyServiceStub A stub to allow clients to do asynchronous rpc calls to service AutoscalingPolicyService.AutoscalingPolicyServiceSettings Settings class to configure an instance ofAutoscalingPolicyServiceClient
.AutoscalingPolicyServiceSettings.Builder Builder for AutoscalingPolicyServiceSettings.AuxiliaryNodeGroup Node group identification and configuration information.AuxiliaryNodeGroup.Builder Node group identification and configuration information.AuxiliaryServicesConfig Auxiliary services configuration for a Cluster.AuxiliaryServicesConfig.Builder Auxiliary services configuration for a Cluster.BasicAutoscalingAlgorithm Basic algorithm for autoscaling.BasicAutoscalingAlgorithm.Builder Basic algorithm for autoscaling.BasicYarnAutoscalingConfig Basic autoscaling configurations for YARN.BasicYarnAutoscalingConfig.Builder Basic autoscaling configurations for YARN.Batch A representation of a batch workload in the service.Batch.Builder A representation of a batch workload in the service.Batch.StateHistory Historical state information.Batch.StateHistory.Builder Historical state information.BatchControllerClient Service Description: The BatchController provides methods to manage batch workloads.BatchControllerClient.ListBatchesFixedSizeCollection BatchControllerClient.ListBatchesPage BatchControllerClient.ListBatchesPagedResponse BatchControllerGrpc The BatchController provides methods to manage batch workloads.BatchControllerGrpc.BatchControllerBlockingStub A stub to allow clients to do synchronous rpc calls to service BatchController.BatchControllerGrpc.BatchControllerFutureStub A stub to allow clients to do ListenableFuture-style rpc calls to service BatchController.BatchControllerGrpc.BatchControllerImplBase Base class for the server implementation of the service BatchController.BatchControllerGrpc.BatchControllerStub A stub to allow clients to do asynchronous rpc calls to service BatchController.BatchControllerSettings Settings class to configure an instance ofBatchControllerClient
.BatchControllerSettings.Builder Builder for BatchControllerSettings.BatchesProto BatchName BatchName.Builder Builder for projects/{project}/locations/{location}/batches/{batch}.BatchOperationMetadata Metadata describing the Batch operation.BatchOperationMetadata.Builder Metadata describing the Batch operation.CancelJobRequest A request to cancel a job.CancelJobRequest.Builder A request to cancel a job.Cluster Describes the identifying information, config, and status of a Dataproc clusterCluster.Builder Describes the identifying information, config, and status of a Dataproc clusterClusterConfig The cluster config.ClusterConfig.Builder The cluster config.ClusterControllerClient Service Description: The ClusterControllerService provides methods to manage clusters of Compute Engine instances.ClusterControllerClient.ListClustersFixedSizeCollection ClusterControllerClient.ListClustersPage ClusterControllerClient.ListClustersPagedResponse ClusterControllerGrpc The ClusterControllerService provides methods to manage clusters of Compute Engine instances.ClusterControllerGrpc.ClusterControllerBlockingStub A stub to allow clients to do synchronous rpc calls to service ClusterController.ClusterControllerGrpc.ClusterControllerFutureStub A stub to allow clients to do ListenableFuture-style rpc calls to service ClusterController.ClusterControllerGrpc.ClusterControllerImplBase Base class for the server implementation of the service ClusterController.ClusterControllerGrpc.ClusterControllerStub A stub to allow clients to do asynchronous rpc calls to service ClusterController.ClusterControllerSettings Settings class to configure an instance ofClusterControllerClient
.ClusterControllerSettings.Builder Builder for ClusterControllerSettings.ClusterMetrics Contains cluster daemon metrics, such as HDFS and YARN stats.ClusterMetrics.Builder Contains cluster daemon metrics, such as HDFS and YARN stats.ClusterOperation The cluster operation triggered by a workflow.ClusterOperation.Builder The cluster operation triggered by a workflow.ClusterOperationMetadata Metadata describing the operation.ClusterOperationMetadata.Builder Metadata describing the operation.ClusterOperationStatus The status of the operation.ClusterOperationStatus.Builder The status of the operation.ClusterRegionName ClusterRegionName.Builder Builder for projects/{project}/regions/{region}/clusters/{cluster}.ClusterSelector A selector that chooses target cluster for jobs based on metadata.ClusterSelector.Builder A selector that chooses target cluster for jobs based on metadata.ClustersProto ClusterStatus The status of a cluster and its instances.ClusterStatus.Builder The status of a cluster and its instances.ConfidentialInstanceConfig Confidential Instance Config for clusters using [Confidential VMs](https://cloud.google.com/compute/confidential-vm/docs)ConfidentialInstanceConfig.Builder Confidential Instance Config for clusters using [Confidential VMs](https://cloud.google.com/compute/confidential-vm/docs)CreateAutoscalingPolicyRequest A request to create an autoscaling policy.CreateAutoscalingPolicyRequest.Builder A request to create an autoscaling policy.CreateBatchRequest A request to create a batch workload.CreateBatchRequest.Builder A request to create a batch workload.CreateClusterRequest A request to create a cluster.CreateClusterRequest.Builder A request to create a cluster.CreateNodeGroupRequest A request to create a node group.CreateNodeGroupRequest.Builder A request to create a node group.CreateWorkflowTemplateRequest A request to create a workflow template.CreateWorkflowTemplateRequest.Builder A request to create a workflow template.DataprocMetricConfig Dataproc metric config.DataprocMetricConfig.Builder Dataproc metric config.DataprocMetricConfig.Metric A Dataproc custom metric.DataprocMetricConfig.Metric.Builder A Dataproc custom metric.DeleteAutoscalingPolicyRequest A request to delete an autoscaling policy.DeleteAutoscalingPolicyRequest.Builder A request to delete an autoscaling policy.DeleteBatchRequest A request to delete a batch workload.DeleteBatchRequest.Builder A request to delete a batch workload.DeleteClusterRequest A request to delete a cluster.DeleteClusterRequest.Builder A request to delete a cluster.DeleteJobRequest A request to delete a job.DeleteJobRequest.Builder A request to delete a job.DeleteWorkflowTemplateRequest A request to delete a workflow template.DeleteWorkflowTemplateRequest.Builder A request to delete a workflow template.DiagnoseClusterRequest A request to collect cluster diagnostic information.DiagnoseClusterRequest.Builder A request to collect cluster diagnostic information.DiagnoseClusterResults The location of diagnostic output.DiagnoseClusterResults.Builder The location of diagnostic output.DiskConfig Specifies the config of disk options for a group of VM instances.DiskConfig.Builder Specifies the config of disk options for a group of VM instances.DriverSchedulingConfig Driver scheduling configuration.DriverSchedulingConfig.Builder Driver scheduling configuration.EncryptionConfig Encryption settings for the cluster.EncryptionConfig.Builder Encryption settings for the cluster.EndpointConfig Endpoint config for this clusterEndpointConfig.Builder Endpoint config for this clusterEnvironmentConfig Environment configuration for a workload.EnvironmentConfig.Builder Environment configuration for a workload.ExecutionConfig Execution configuration for a workload.ExecutionConfig.Builder Execution configuration for a workload.GceClusterConfig Common config settings for resources of Compute Engine cluster instances, applicable to all instances in the cluster.GceClusterConfig.Builder Common config settings for resources of Compute Engine cluster instances, applicable to all instances in the cluster.GetAutoscalingPolicyRequest A request to fetch an autoscaling policy.GetAutoscalingPolicyRequest.Builder A request to fetch an autoscaling policy.GetBatchRequest A request to get the resource representation for a batch workload.GetBatchRequest.Builder A request to get the resource representation for a batch workload.GetClusterRequest Request to get the resource representation for a cluster in a project.GetClusterRequest.Builder Request to get the resource representation for a cluster in a project.GetJobRequest A request to get the resource representation for a job in a project.GetJobRequest.Builder A request to get the resource representation for a job in a project.GetNodeGroupRequest A request to get a node group .GetNodeGroupRequest.Builder A request to get a node group .GetWorkflowTemplateRequest A request to fetch a workflow template.GetWorkflowTemplateRequest.Builder A request to fetch a workflow template.GkeClusterConfig The cluster's GKE config.GkeClusterConfig.Builder The cluster's GKE config.GkeNodePoolConfig The configuration of a GKE node pool used by a [Dataproc-on-GKE cluster](https://cloud.google.com/dataproc/docs/concepts/jobs/dataproc-gke#create-a-dataproc-on-gke-cluster).GkeNodePoolConfig.Builder The configuration of a GKE node pool used by a [Dataproc-on-GKE cluster](https://cloud.google.com/dataproc/docs/concepts/jobs/dataproc-gke#create-a-dataproc-on-gke-cluster).GkeNodePoolConfig.GkeNodeConfig Parameters that describe cluster nodes.GkeNodePoolConfig.GkeNodeConfig.Builder Parameters that describe cluster nodes.GkeNodePoolConfig.GkeNodePoolAcceleratorConfig A GkeNodeConfigAcceleratorConfig represents a Hardware Accelerator request for a node pool.GkeNodePoolConfig.GkeNodePoolAcceleratorConfig.Builder A GkeNodeConfigAcceleratorConfig represents a Hardware Accelerator request for a node pool.GkeNodePoolConfig.GkeNodePoolAutoscalingConfig GkeNodePoolAutoscaling contains information the cluster autoscaler needs to adjust the size of the node pool to the current cluster usage.GkeNodePoolConfig.GkeNodePoolAutoscalingConfig.Builder GkeNodePoolAutoscaling contains information the cluster autoscaler needs to adjust the size of the node pool to the current cluster usage.GkeNodePoolTarget GKE node pools that Dataproc workloads run on.GkeNodePoolTarget.Builder GKE node pools that Dataproc workloads run on.HadoopJob A Dataproc job for running [Apache Hadoop MapReduce](https://hadoop.apache.org/docs/current/hadoop-mapreduce-client/hadoop-mapreduce-client-core/MapReduceTutorial.html) jobs on [Apache Hadoop YARN](https://hadoop.apache.org/docs/r2.7.1/hadoop-yarn/hadoop-yarn-site/YARN.html).HadoopJob.Builder A Dataproc job for running [Apache Hadoop MapReduce](https://hadoop.apache.org/docs/current/hadoop-mapreduce-client/hadoop-mapreduce-client-core/MapReduceTutorial.html) jobs on [Apache Hadoop YARN](https://hadoop.apache.org/docs/r2.7.1/hadoop-yarn/hadoop-yarn-site/YARN.html).HiveJob A Dataproc job for running [Apache Hive](https://hive.apache.org/) queries on YARN.HiveJob.Builder A Dataproc job for running [Apache Hive](https://hive.apache.org/) queries on YARN.IdentityConfig Identity related configuration, including service account based secure multi-tenancy user mappings.IdentityConfig.Builder Identity related configuration, including service account based secure multi-tenancy user mappings.InstanceFlexibilityPolicy Instance flexibility Policy allowing a mixture of VM shapes and provisioning models.InstanceFlexibilityPolicy.Builder Instance flexibility Policy allowing a mixture of VM shapes and provisioning models.InstanceFlexibilityPolicy.InstanceSelection Defines machines types and a rank to which the machines types belong.InstanceFlexibilityPolicy.InstanceSelection.Builder Defines machines types and a rank to which the machines types belong.InstanceFlexibilityPolicy.InstanceSelectionResult Defines a mapping from machine types to the number of VMs that are created with each machine type.InstanceFlexibilityPolicy.InstanceSelectionResult.Builder Defines a mapping from machine types to the number of VMs that are created with each machine type.InstanceGroupAutoscalingPolicyConfig Configuration for the size bounds of an instance group, including its proportional size to other groups.InstanceGroupAutoscalingPolicyConfig.Builder Configuration for the size bounds of an instance group, including its proportional size to other groups.InstanceGroupConfig The config settings for Compute Engine resources in an instance group, such as a master or worker group.InstanceGroupConfig.Builder The config settings for Compute Engine resources in an instance group, such as a master or worker group.InstanceReference A reference to a Compute Engine instance.InstanceReference.Builder A reference to a Compute Engine instance.InstantiateInlineWorkflowTemplateRequest A request to instantiate an inline workflow template.InstantiateInlineWorkflowTemplateRequest.Builder A request to instantiate an inline workflow template.InstantiateWorkflowTemplateRequest A request to instantiate a workflow template.InstantiateWorkflowTemplateRequest.Builder A request to instantiate a workflow template.Job A Dataproc job resource.Job.Builder A Dataproc job resource.JobControllerClient Service Description: The JobController provides methods to manage jobs.JobControllerClient.ListJobsFixedSizeCollection JobControllerClient.ListJobsPage JobControllerClient.ListJobsPagedResponse JobControllerGrpc The JobController provides methods to manage jobs.JobControllerGrpc.JobControllerBlockingStub A stub to allow clients to do synchronous rpc calls to service JobController.JobControllerGrpc.JobControllerFutureStub A stub to allow clients to do ListenableFuture-style rpc calls to service JobController.JobControllerGrpc.JobControllerImplBase Base class for the server implementation of the service JobController.JobControllerGrpc.JobControllerStub A stub to allow clients to do asynchronous rpc calls to service JobController.JobControllerSettings Settings class to configure an instance ofJobControllerClient
.JobControllerSettings.Builder Builder for JobControllerSettings.JobMetadata Job Operation metadata.JobMetadata.Builder Job Operation metadata.JobPlacement Dataproc job config.JobPlacement.Builder Dataproc job config.JobReference Encapsulates the full scoping used to reference a job.JobReference.Builder Encapsulates the full scoping used to reference a job.JobScheduling Job scheduling options.JobScheduling.Builder Job scheduling options.JobsProto JobStatus Dataproc job status.JobStatus.Builder Dataproc job status.KerberosConfig Specifies Kerberos related configuration.KerberosConfig.Builder Specifies Kerberos related configuration.KubernetesClusterConfig The configuration for running the Dataproc cluster on Kubernetes.KubernetesClusterConfig.Builder The configuration for running the Dataproc cluster on Kubernetes.KubernetesSoftwareConfig The software configuration for this Dataproc cluster running on Kubernetes.KubernetesSoftwareConfig.Builder The software configuration for this Dataproc cluster running on Kubernetes.LifecycleConfig Specifies the cluster auto-delete schedule configuration.LifecycleConfig.Builder Specifies the cluster auto-delete schedule configuration.ListAutoscalingPoliciesRequest A request to list autoscaling policies in a project.ListAutoscalingPoliciesRequest.Builder A request to list autoscaling policies in a project.ListAutoscalingPoliciesResponse A response to a request to list autoscaling policies in a project.ListAutoscalingPoliciesResponse.Builder A response to a request to list autoscaling policies in a project.ListBatchesRequest A request to list batch workloads in a project.ListBatchesRequest.Builder A request to list batch workloads in a project.ListBatchesResponse A list of batch workloads.ListBatchesResponse.Builder A list of batch workloads.ListClustersRequest A request to list the clusters in a project.ListClustersRequest.Builder A request to list the clusters in a project.ListClustersResponse The list of all clusters in a project.ListClustersResponse.Builder The list of all clusters in a project.ListJobsRequest A request to list jobs in a project.ListJobsRequest.Builder A request to list jobs in a project.ListJobsResponse A list of jobs in a project.ListJobsResponse.Builder A list of jobs in a project.ListWorkflowTemplatesRequest A request to list workflow templates in a project.ListWorkflowTemplatesRequest.Builder A request to list workflow templates in a project.ListWorkflowTemplatesResponse A response to a request to list workflow templates in a project.ListWorkflowTemplatesResponse.Builder A response to a request to list workflow templates in a project.LocationName LocationName.Builder Builder for projects/{project}/locations/{location}.LoggingConfig The runtime logging config of the job.LoggingConfig.Builder The runtime logging config of the job.ManagedCluster Cluster that is managed by the workflow.ManagedCluster.Builder Cluster that is managed by the workflow.ManagedGroupConfig Specifies the resources used to actively manage an instance group.ManagedGroupConfig.Builder Specifies the resources used to actively manage an instance group.MetastoreConfig Specifies a Metastore configuration.MetastoreConfig.Builder Specifies a Metastore configuration.NodeGroup Dataproc Node Group.NodeGroup.Builder Dataproc Node Group.NodeGroupAffinity Node Group Affinity for clusters using sole-tenant node groups.NodeGroupAffinity.Builder Node Group Affinity for clusters using sole-tenant node groups.NodeGroupControllerClient Service Description: The `NodeGroupControllerService` provides methods to manage node groups of Compute Engine managed instances.NodeGroupControllerGrpc The `NodeGroupControllerService` provides methods to manage node groups of Compute Engine managed instances.NodeGroupControllerGrpc.NodeGroupControllerBlockingStub A stub to allow clients to do synchronous rpc calls to service NodeGroupController.NodeGroupControllerGrpc.NodeGroupControllerFutureStub A stub to allow clients to do ListenableFuture-style rpc calls to service NodeGroupController.NodeGroupControllerGrpc.NodeGroupControllerImplBase Base class for the server implementation of the service NodeGroupController.NodeGroupControllerGrpc.NodeGroupControllerStub A stub to allow clients to do asynchronous rpc calls to service NodeGroupController.NodeGroupControllerSettings Settings class to configure an instance ofNodeGroupControllerClient
.NodeGroupControllerSettings.Builder Builder for NodeGroupControllerSettings.NodeGroupName NodeGroupName.Builder Builder for projects/{project}/regions/{region}/clusters/{cluster}/nodeGroups/{node_group}.NodeGroupOperationMetadata Metadata describing the node group operation.NodeGroupOperationMetadata.Builder Metadata describing the node group operation.NodeGroupsProto NodeInitializationAction Specifies an executable to run on a fully configured node and a timeout period for executable completion.NodeInitializationAction.Builder Specifies an executable to run on a fully configured node and a timeout period for executable completion.OperationsProto OrderedJob A job executed by the workflow.OrderedJob.Builder A job executed by the workflow.ParameterValidation Configuration for parameter validation.ParameterValidation.Builder Configuration for parameter validation.PeripheralsConfig Auxiliary services configuration for a workload.PeripheralsConfig.Builder Auxiliary services configuration for a workload.PigJob A Dataproc job for running [Apache Pig](https://pig.apache.org/) queries on YARN.PigJob.Builder A Dataproc job for running [Apache Pig](https://pig.apache.org/) queries on YARN.PrestoJob A Dataproc job for running [Presto](https://prestosql.io/) queries.PrestoJob.Builder A Dataproc job for running [Presto](https://prestosql.io/) queries.PySparkBatch A configuration for running an [Apache PySpark](https://spark.apache.org/docs/latest/api/python/getting_started/quickstart.html) batch workload.PySparkBatch.Builder A configuration for running an [Apache PySpark](https://spark.apache.org/docs/latest/api/python/getting_started/quickstart.html) batch workload.PySparkJob A Dataproc job for running [Apache PySpark](https://spark.apache.org/docs/0.9.0/python-programming-guide.html) applications on YARN.PySparkJob.Builder A Dataproc job for running [Apache PySpark](https://spark.apache.org/docs/0.9.0/python-programming-guide.html) applications on YARN.QueryList A list of queries to run on a cluster.QueryList.Builder A list of queries to run on a cluster.RegexValidation Validation based on regular expressions.RegexValidation.Builder Validation based on regular expressions.RegionName RegionName.Builder Builder for projects/{project}/regions/{region}.ReservationAffinity Reservation Affinity for consuming Zonal reservation.ReservationAffinity.Builder Reservation Affinity for consuming Zonal reservation.ResizeNodeGroupRequest A request to resize a node group.ResizeNodeGroupRequest.Builder A request to resize a node group.RuntimeConfig Runtime configuration for a workload.RuntimeConfig.Builder Runtime configuration for a workload.RuntimeInfo Runtime information about workload execution.RuntimeInfo.Builder Runtime information about workload execution.SecurityConfig Security related configuration, including encryption, Kerberos, etc.SecurityConfig.Builder Security related configuration, including encryption, Kerberos, etc.SharedProto ShieldedInstanceConfig Shielded Instance Config for clusters using [Compute Engine Shielded VMs](https://cloud.google.com/security/shielded-cloud/shielded-vm).ShieldedInstanceConfig.Builder Shielded Instance Config for clusters using [Compute Engine Shielded VMs](https://cloud.google.com/security/shielded-cloud/shielded-vm).SoftwareConfig Specifies the selection and config of software inside the cluster.SoftwareConfig.Builder Specifies the selection and config of software inside the cluster.SparkBatch A configuration for running an [Apache Spark](https://spark.apache.org/) batch workload.SparkBatch.Builder A configuration for running an [Apache Spark](https://spark.apache.org/) batch workload.SparkHistoryServerConfig Spark History Server configuration for the workload.SparkHistoryServerConfig.Builder Spark History Server configuration for the workload.SparkJob A Dataproc job for running [Apache Spark](https://spark.apache.org/) applications on YARN.SparkJob.Builder A Dataproc job for running [Apache Spark](https://spark.apache.org/) applications on YARN.SparkRBatch A configuration for running an [Apache SparkR](https://spark.apache.org/docs/latest/sparkr.html) batch workload.SparkRBatch.Builder A configuration for running an [Apache SparkR](https://spark.apache.org/docs/latest/sparkr.html) batch workload.SparkRJob A Dataproc job for running [Apache SparkR](https://spark.apache.org/docs/latest/sparkr.html) applications on YARN.SparkRJob.Builder A Dataproc job for running [Apache SparkR](https://spark.apache.org/docs/latest/sparkr.html) applications on YARN.SparkSqlBatch A configuration for running [Apache Spark SQL](https://spark.apache.org/sql/) queries as a batch workload.SparkSqlBatch.Builder A configuration for running [Apache Spark SQL](https://spark.apache.org/sql/) queries as a batch workload.SparkSqlJob A Dataproc job for running [Apache Spark SQL](https://spark.apache.org/sql/) queries.SparkSqlJob.Builder A Dataproc job for running [Apache Spark SQL](https://spark.apache.org/sql/) queries.StartClusterRequest A request to start a cluster.StartClusterRequest.Builder A request to start a cluster.StopClusterRequest A request to stop a cluster.StopClusterRequest.Builder A request to stop a cluster.SubmitJobRequest A request to submit a job.SubmitJobRequest.Builder A request to submit a job.TemplateParameter A configurable parameter that replaces one or more fields in the template.TemplateParameter.Builder A configurable parameter that replaces one or more fields in the template.TrinoJob A Dataproc job for running [Trino](https://trino.io/) queries.TrinoJob.Builder A Dataproc job for running [Trino](https://trino.io/) queries.UpdateAutoscalingPolicyRequest A request to update an autoscaling policy.UpdateAutoscalingPolicyRequest.Builder A request to update an autoscaling policy.UpdateClusterRequest A request to update a cluster.UpdateClusterRequest.Builder A request to update a cluster.UpdateJobRequest A request to update a job.UpdateJobRequest.Builder A request to update a job.UpdateWorkflowTemplateRequest A request to update a workflow template.UpdateWorkflowTemplateRequest.Builder A request to update a workflow template.UsageMetrics Usage metrics represent approximate total resources consumed by a workload.UsageMetrics.Builder Usage metrics represent approximate total resources consumed by a workload.UsageSnapshot The usage snaphot represents the resources consumed by a workload at a specified time.UsageSnapshot.Builder The usage snaphot represents the resources consumed by a workload at a specified time.ValueValidation Validation based on a list of allowed values.ValueValidation.Builder Validation based on a list of allowed values.VirtualClusterConfig The Dataproc cluster config for a cluster that does not directly control the underlying compute resources, such as a [Dataproc-on-GKE cluster](https://cloud.google.com/dataproc/docs/guides/dpgke/dataproc-gke-overview).VirtualClusterConfig.Builder The Dataproc cluster config for a cluster that does not directly control the underlying compute resources, such as a [Dataproc-on-GKE cluster](https://cloud.google.com/dataproc/docs/guides/dpgke/dataproc-gke-overview).WorkflowGraph The workflow graph.WorkflowGraph.Builder The workflow graph.WorkflowMetadata A Dataproc workflow template resource.WorkflowMetadata.Builder A Dataproc workflow template resource.WorkflowNode The workflow node.WorkflowNode.Builder The workflow node.WorkflowTemplate A Dataproc workflow template resource.WorkflowTemplate.Builder A Dataproc workflow template resource.WorkflowTemplateName WorkflowTemplateName.Builder Builder for projects/{project}/regions/{region}/workflowTemplates/{workflow_template}.WorkflowTemplateName.ProjectLocationWorkflowTemplateBuilder Builder for projects/{project}/locations/{location}/workflowTemplates/{workflow_template}.WorkflowTemplatePlacement Specifies workflow execution target.WorkflowTemplatePlacement.Builder Specifies workflow execution target.WorkflowTemplateServiceClient Service Description: The API interface for managing Workflow Templates in the Dataproc API.WorkflowTemplateServiceClient.ListWorkflowTemplatesFixedSizeCollection WorkflowTemplateServiceClient.ListWorkflowTemplatesPage WorkflowTemplateServiceClient.ListWorkflowTemplatesPagedResponse WorkflowTemplateServiceGrpc The API interface for managing Workflow Templates in the Dataproc API.WorkflowTemplateServiceGrpc.WorkflowTemplateServiceBlockingStub A stub to allow clients to do synchronous rpc calls to service WorkflowTemplateService.WorkflowTemplateServiceGrpc.WorkflowTemplateServiceFutureStub A stub to allow clients to do ListenableFuture-style rpc calls to service WorkflowTemplateService.WorkflowTemplateServiceGrpc.WorkflowTemplateServiceImplBase Base class for the server implementation of the service WorkflowTemplateService.WorkflowTemplateServiceGrpc.WorkflowTemplateServiceStub A stub to allow clients to do asynchronous rpc calls to service WorkflowTemplateService.WorkflowTemplateServiceSettings Settings class to configure an instance ofWorkflowTemplateServiceClient
.WorkflowTemplateServiceSettings.Builder Builder for WorkflowTemplateServiceSettings.WorkflowTemplatesProto YarnApplication A YARN application created by a job.YarnApplication.Builder A YARN application created by a job. -
Enum Summary Enum Description AutoscalingPolicy.AlgorithmCase BasicAutoscalingAlgorithm.ConfigCase Batch.BatchConfigCase Batch.State The batch state.BatchOperationMetadata.BatchOperationType Operation type for Batch resourcesClusterOperationStatus.State The operation state.ClusterStatus.State The cluster state.ClusterStatus.Substate The cluster substate.Component Cluster components that can be activated.DataprocMetricConfig.MetricSource A source for the collection of Dataproc custom metrics (see [Custom metrics] (https://cloud.google.com//dataproc/docs/guides/dataproc-metrics#custom_metrics)).ExecutionConfig.NetworkCase FailureAction Actions in response to failure of a resource associated with a cluster.GceClusterConfig.PrivateIpv6GoogleAccess `PrivateIpv6GoogleAccess` controls whether and how Dataproc cluster nodes can communicate with Google Services through gRPC over IPv6.GkeNodePoolTarget.Role `Role` specifies the tasks that will run on the node pool.HadoopJob.DriverCase HiveJob.QueriesCase InstanceGroupConfig.Preemptibility Controls the use of preemptible instances within the group.Job.TypeJobCase JobStatus.State The job state.JobStatus.Substate The job substate.KubernetesClusterConfig.ConfigCase LifecycleConfig.TtlCase ListJobsRequest.JobStateMatcher A matcher that specifies categories of job states.LoggingConfig.Level The Log4j level for job execution.NodeGroup.Role Node group roles.NodeGroupOperationMetadata.NodeGroupOperationType Operation type for node group resources.OrderedJob.JobTypeCase ParameterValidation.ValidationTypeCase PigJob.QueriesCase PrestoJob.QueriesCase ReservationAffinity.Type Indicates whether to consume capacity from an reservation or not.SparkBatch.DriverCase SparkJob.DriverCase SparkSqlJob.QueriesCase TrinoJob.QueriesCase VirtualClusterConfig.InfrastructureConfigCase WorkflowMetadata.State The operation state.WorkflowNode.NodeState The workflow node state.WorkflowTemplatePlacement.PlacementCase YarnApplication.State The application state, corresponding to <code>YarnProtos.YarnApplicationStateProto</code>.