@Generated("by gapic-generator-java")
Package com.google.dataflow.v1beta3
The interfaces provided are listed below, along with usage samples.
======================= JobsV1Beta3Client =======================
Service Description: Provides a method to create and modify Google Cloud Dataflow jobs. A Job is a multi-stage computation graph run by the Cloud Dataflow service.
Sample for JobsV1Beta3Client:
// 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 (JobsV1Beta3Client jobsV1Beta3Client = JobsV1Beta3Client.create()) {
CreateJobRequest request =
CreateJobRequest.newBuilder()
.setProjectId("projectId-894832108")
.setJob(Job.newBuilder().build())
.setView(JobView.forNumber(0))
.setReplaceJobId("replaceJobId441554788")
.setLocation("location1901043637")
.build();
Job response = jobsV1Beta3Client.createJob(request);
}
======================= MessagesV1Beta3Client =======================
Service Description: The Dataflow Messages API is used for monitoring the progress of Dataflow jobs.
Sample for MessagesV1Beta3Client:
// 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 (MessagesV1Beta3Client messagesV1Beta3Client = MessagesV1Beta3Client.create()) {
ListJobMessagesRequest request =
ListJobMessagesRequest.newBuilder()
.setProjectId("projectId-894832108")
.setJobId("jobId101296568")
.setMinimumImportance(JobMessageImportance.forNumber(0))
.setPageSize(883849137)
.setPageToken("pageToken873572522")
.setStartTime(Timestamp.newBuilder().build())
.setEndTime(Timestamp.newBuilder().build())
.setLocation("location1901043637")
.build();
for (JobMessage element : messagesV1Beta3Client.listJobMessages(request).iterateAll()) {
// doThingsWith(element);
}
}
======================= MetricsV1Beta3Client =======================
Service Description: The Dataflow Metrics API lets you monitor the progress of Dataflow jobs.
Sample for MetricsV1Beta3Client:
// 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 (MetricsV1Beta3Client metricsV1Beta3Client = MetricsV1Beta3Client.create()) {
GetJobMetricsRequest request =
GetJobMetricsRequest.newBuilder()
.setProjectId("projectId-894832108")
.setJobId("jobId101296568")
.setStartTime(Timestamp.newBuilder().build())
.setLocation("location1901043637")
.build();
JobMetrics response = metricsV1Beta3Client.getJobMetrics(request);
}
======================= SnapshotsV1Beta3Client =======================
Service Description: Provides methods to manage snapshots of Google Cloud Dataflow jobs.
Sample for SnapshotsV1Beta3Client:
// 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 (SnapshotsV1Beta3Client snapshotsV1Beta3Client = SnapshotsV1Beta3Client.create()) {
GetSnapshotRequest request =
GetSnapshotRequest.newBuilder()
.setProjectId("projectId-894832108")
.setSnapshotId("snapshotId-1113817601")
.setLocation("location1901043637")
.build();
Snapshot response = snapshotsV1Beta3Client.getSnapshot(request);
}
======================= TemplatesServiceClient =======================
Service Description: Provides a method to create Cloud Dataflow jobs from templates.
Sample for TemplatesServiceClient:
// 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 (TemplatesServiceClient templatesServiceClient = TemplatesServiceClient.create()) {
CreateJobFromTemplateRequest request =
CreateJobFromTemplateRequest.newBuilder()
.setProjectId("projectId-894832108")
.setJobName("jobName-1438096408")
.putAllParameters(new HashMap<String, String>())
.setEnvironment(RuntimeEnvironment.newBuilder().build())
.setLocation("location1901043637")
.build();
Job response = templatesServiceClient.createJobFromTemplate(request);
}
======================= FlexTemplatesServiceClient =======================
Service Description: Provides a service for Flex templates. This feature is not ready yet.
Sample for FlexTemplatesServiceClient:
// 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 (FlexTemplatesServiceClient flexTemplatesServiceClient =
FlexTemplatesServiceClient.create()) {
LaunchFlexTemplateRequest request =
LaunchFlexTemplateRequest.newBuilder()
.setProjectId("projectId-894832108")
.setLaunchParameter(LaunchFlexTemplateParameter.newBuilder().build())
.setLocation("location1901043637")
.setValidateOnly(true)
.build();
LaunchFlexTemplateResponse response = flexTemplatesServiceClient.launchFlexTemplate(request);
}
-
Class Summary Class Description AutoscalingEvent A structured message reporting an autoscaling decision made by the Dataflow service.AutoscalingEvent.Builder A structured message reporting an autoscaling decision made by the Dataflow service.AutoscalingSettings Settings for WorkerPool autoscaling.AutoscalingSettings.Builder Settings for WorkerPool autoscaling.BigQueryIODetails Metadata for a BigQuery connector used by the job.BigQueryIODetails.Builder Metadata for a BigQuery connector used by the job.BigTableIODetails Metadata for a Cloud Bigtable connector used by the job.BigTableIODetails.Builder Metadata for a Cloud Bigtable connector used by the job.CheckActiveJobsRequest Request to check is active jobs exists for a projectCheckActiveJobsRequest.Builder Request to check is active jobs exists for a projectCheckActiveJobsResponse Response for CheckActiveJobsRequest.CheckActiveJobsResponse.Builder Response for CheckActiveJobsRequest.ComputationTopology All configuration data for a particular Computation.ComputationTopology.Builder All configuration data for a particular Computation.ContainerSpec Container Spec.ContainerSpec.Builder Container Spec.CreateJobFromTemplateRequest A request to create a Cloud Dataflow job from a template.CreateJobFromTemplateRequest.Builder A request to create a Cloud Dataflow job from a template.CreateJobRequest Request to create a Cloud Dataflow job.CreateJobRequest.Builder Request to create a Cloud Dataflow job.CustomSourceLocation Identifies the location of a custom souce.CustomSourceLocation.Builder Identifies the location of a custom souce.DataDiskAssignment Data disk assignment for a given VM instance.DataDiskAssignment.Builder Data disk assignment for a given VM instance.DatastoreIODetails Metadata for a Datastore connector used by the job.DatastoreIODetails.Builder Metadata for a Datastore connector used by the job.DebugOptions Describes any options that have an effect on the debugging of pipelines.DebugOptions.Builder Describes any options that have an effect on the debugging of pipelines.DeleteSnapshotRequest Request to delete a snapshot.DeleteSnapshotRequest.Builder Request to delete a snapshot.DeleteSnapshotResponse Response from deleting a snapshot.DeleteSnapshotResponse.Builder Response from deleting a snapshot.Disk Describes the data disk used by a workflow job.Disk.Builder Describes the data disk used by a workflow job.DisplayData Data provided with a pipeline or transform to provide descriptive info.DisplayData.Builder Data provided with a pipeline or transform to provide descriptive info.DynamicTemplateLaunchParams Params which should be passed when launching a dynamic template.DynamicTemplateLaunchParams.Builder Params which should be passed when launching a dynamic template.Environment Describes the environment in which a Dataflow Job runs.Environment.Builder Describes the environment in which a Dataflow Job runs.EnvironmentProto ExecutionStageState A message describing the state of a particular execution stage.ExecutionStageState.Builder A message describing the state of a particular execution stage.ExecutionStageSummary Description of the composing transforms, names/ids, and input/outputs of a stage of execution.ExecutionStageSummary.Builder Description of the composing transforms, names/ids, and input/outputs of a stage of execution.ExecutionStageSummary.ComponentSource Description of an interstitial value between transforms in an execution stage.ExecutionStageSummary.ComponentSource.Builder Description of an interstitial value between transforms in an execution stage.ExecutionStageSummary.ComponentTransform Description of a transform executed as part of an execution stage.ExecutionStageSummary.ComponentTransform.Builder Description of a transform executed as part of an execution stage.ExecutionStageSummary.StageSource Description of an input or output of an execution stage.ExecutionStageSummary.StageSource.Builder Description of an input or output of an execution stage.FailedLocation Indicates which [regional endpoint] (https://cloud.google.com/dataflow/docs/concepts/regional-endpoints) failed to respond to a request for data.FailedLocation.Builder Indicates which [regional endpoint] (https://cloud.google.com/dataflow/docs/concepts/regional-endpoints) failed to respond to a request for data.FileIODetails Metadata for a File connector used by the job.FileIODetails.Builder Metadata for a File connector used by the job.FlexTemplateRuntimeEnvironment The environment values to be set at runtime for flex template.FlexTemplateRuntimeEnvironment.Builder The environment values to be set at runtime for flex template.FlexTemplatesServiceClient Service Description: Provides a service for Flex templates.FlexTemplatesServiceGrpc Provides a service for Flex templates.FlexTemplatesServiceGrpc.FlexTemplatesServiceBlockingStub A stub to allow clients to do synchronous rpc calls to service FlexTemplatesService.FlexTemplatesServiceGrpc.FlexTemplatesServiceFutureStub A stub to allow clients to do ListenableFuture-style rpc calls to service FlexTemplatesService.FlexTemplatesServiceGrpc.FlexTemplatesServiceImplBase Base class for the server implementation of the service FlexTemplatesService.FlexTemplatesServiceGrpc.FlexTemplatesServiceStub A stub to allow clients to do asynchronous rpc calls to service FlexTemplatesService.FlexTemplatesServiceSettings Settings class to configure an instance ofFlexTemplatesServiceClient
.FlexTemplatesServiceSettings.Builder Builder for FlexTemplatesServiceSettings.GetJobExecutionDetailsRequest Request to get job execution details.GetJobExecutionDetailsRequest.Builder Request to get job execution details.GetJobMetricsRequest Request to get job metrics.GetJobMetricsRequest.Builder Request to get job metrics.GetJobRequest Request to get the state of a Cloud Dataflow job.GetJobRequest.Builder Request to get the state of a Cloud Dataflow job.GetSnapshotRequest Request to get information about a snapshotGetSnapshotRequest.Builder Request to get information about a snapshotGetStageExecutionDetailsRequest Request to get information about a particular execution stage of a job.GetStageExecutionDetailsRequest.Builder Request to get information about a particular execution stage of a job.GetTemplateRequest A request to retrieve a Cloud Dataflow job template.GetTemplateRequest.Builder A request to retrieve a Cloud Dataflow job template.GetTemplateResponse The response to a GetTemplate request.GetTemplateResponse.Builder The response to a GetTemplate request.InvalidTemplateParameters Used in the error_details field of a google.rpc.Status message, this indicates problems with the template parameter.InvalidTemplateParameters.Builder Used in the error_details field of a google.rpc.Status message, this indicates problems with the template parameter.InvalidTemplateParameters.ParameterViolation A specific template-parameter violation.InvalidTemplateParameters.ParameterViolation.Builder A specific template-parameter violation.Job Defines a job to be run by the Cloud Dataflow service.Job.Builder Defines a job to be run by the Cloud Dataflow service.JobExecutionDetails Information about the execution of a job.JobExecutionDetails.Builder Information about the execution of a job.JobExecutionInfo Additional information about how a Cloud Dataflow job will be executed that isn't contained in the submitted job.JobExecutionInfo.Builder Additional information about how a Cloud Dataflow job will be executed that isn't contained in the submitted job.JobExecutionStageInfo Contains information about how a particular [google.dataflow.v1beta3.Step][google.dataflow.v1beta3.Step] will be executed.JobExecutionStageInfo.Builder Contains information about how a particular [google.dataflow.v1beta3.Step][google.dataflow.v1beta3.Step] will be executed.JobMessage A particular message pertaining to a Dataflow job.JobMessage.Builder A particular message pertaining to a Dataflow job.JobMetadata Metadata available primarily for filtering jobs.JobMetadata.Builder Metadata available primarily for filtering jobs.JobMetrics JobMetrics contains a collection of metrics describing the detailed progress of a Dataflow job.JobMetrics.Builder JobMetrics contains a collection of metrics describing the detailed progress of a Dataflow job.JobsProto JobsV1Beta3Client Service Description: Provides a method to create and modify Google Cloud Dataflow jobs.JobsV1Beta3Client.AggregatedListJobsFixedSizeCollection JobsV1Beta3Client.AggregatedListJobsPage JobsV1Beta3Client.AggregatedListJobsPagedResponse JobsV1Beta3Client.ListJobsFixedSizeCollection JobsV1Beta3Client.ListJobsPage JobsV1Beta3Client.ListJobsPagedResponse JobsV1Beta3Grpc Provides a method to create and modify Google Cloud Dataflow jobs.JobsV1Beta3Grpc.JobsV1Beta3BlockingStub A stub to allow clients to do synchronous rpc calls to service JobsV1Beta3.JobsV1Beta3Grpc.JobsV1Beta3FutureStub A stub to allow clients to do ListenableFuture-style rpc calls to service JobsV1Beta3.JobsV1Beta3Grpc.JobsV1Beta3ImplBase Base class for the server implementation of the service JobsV1Beta3.JobsV1Beta3Grpc.JobsV1Beta3Stub A stub to allow clients to do asynchronous rpc calls to service JobsV1Beta3.JobsV1Beta3Settings Settings class to configure an instance ofJobsV1Beta3Client
.JobsV1Beta3Settings.Builder Builder for JobsV1Beta3Settings.KeyRangeDataDiskAssignment Data disk assignment information for a specific key-range of a sharded computation.KeyRangeDataDiskAssignment.Builder Data disk assignment information for a specific key-range of a sharded computation.KeyRangeLocation Location information for a specific key-range of a sharded computation.KeyRangeLocation.Builder Location information for a specific key-range of a sharded computation.LaunchFlexTemplateParameter Launch FlexTemplate Parameter.LaunchFlexTemplateParameter.Builder Launch FlexTemplate Parameter.LaunchFlexTemplateRequest A request to launch a Cloud Dataflow job from a FlexTemplate.LaunchFlexTemplateRequest.Builder A request to launch a Cloud Dataflow job from a FlexTemplate.LaunchFlexTemplateResponse Response to the request to launch a job from Flex Template.LaunchFlexTemplateResponse.Builder Response to the request to launch a job from Flex Template.LaunchTemplateParameters Parameters to provide to the template being launched.LaunchTemplateParameters.Builder Parameters to provide to the template being launched.LaunchTemplateRequest A request to launch a template.LaunchTemplateRequest.Builder A request to launch a template.LaunchTemplateResponse Response to the request to launch a template.LaunchTemplateResponse.Builder Response to the request to launch a template.ListJobMessagesRequest Request to list job messages.ListJobMessagesRequest.Builder Request to list job messages.ListJobMessagesResponse Response to a request to list job messages.ListJobMessagesResponse.Builder Response to a request to list job messages.ListJobsRequest Request to list Cloud Dataflow jobs.ListJobsRequest.Builder Request to list Cloud Dataflow jobs.ListJobsResponse Response to a request to list Cloud Dataflow jobs in a project.ListJobsResponse.Builder Response to a request to list Cloud Dataflow jobs in a project.ListSnapshotsRequest Request to list snapshots.ListSnapshotsRequest.Builder Request to list snapshots.ListSnapshotsResponse List of snapshots.ListSnapshotsResponse.Builder List of snapshots.MessagesProto MessagesV1Beta3Client Service Description: The Dataflow Messages API is used for monitoring the progress of Dataflow jobs.MessagesV1Beta3Client.ListJobMessagesFixedSizeCollection MessagesV1Beta3Client.ListJobMessagesPage MessagesV1Beta3Client.ListJobMessagesPagedResponse MessagesV1Beta3Grpc The Dataflow Messages API is used for monitoring the progress of Dataflow jobs.MessagesV1Beta3Grpc.MessagesV1Beta3BlockingStub A stub to allow clients to do synchronous rpc calls to service MessagesV1Beta3.MessagesV1Beta3Grpc.MessagesV1Beta3FutureStub A stub to allow clients to do ListenableFuture-style rpc calls to service MessagesV1Beta3.MessagesV1Beta3Grpc.MessagesV1Beta3ImplBase Base class for the server implementation of the service MessagesV1Beta3.MessagesV1Beta3Grpc.MessagesV1Beta3Stub A stub to allow clients to do asynchronous rpc calls to service MessagesV1Beta3.MessagesV1Beta3Settings Settings class to configure an instance ofMessagesV1Beta3Client
.MessagesV1Beta3Settings.Builder Builder for MessagesV1Beta3Settings.MetricsProto MetricStructuredName Identifies a metric, by describing the source which generated the metric.MetricStructuredName.Builder Identifies a metric, by describing the source which generated the metric.MetricsV1Beta3Client Service Description: The Dataflow Metrics API lets you monitor the progress of Dataflow jobs.MetricsV1Beta3Client.GetJobExecutionDetailsFixedSizeCollection MetricsV1Beta3Client.GetJobExecutionDetailsPage MetricsV1Beta3Client.GetJobExecutionDetailsPagedResponse MetricsV1Beta3Client.GetStageExecutionDetailsFixedSizeCollection MetricsV1Beta3Client.GetStageExecutionDetailsPage MetricsV1Beta3Client.GetStageExecutionDetailsPagedResponse MetricsV1Beta3Grpc The Dataflow Metrics API lets you monitor the progress of Dataflow jobs.MetricsV1Beta3Grpc.MetricsV1Beta3BlockingStub A stub to allow clients to do synchronous rpc calls to service MetricsV1Beta3.MetricsV1Beta3Grpc.MetricsV1Beta3FutureStub A stub to allow clients to do ListenableFuture-style rpc calls to service MetricsV1Beta3.MetricsV1Beta3Grpc.MetricsV1Beta3ImplBase Base class for the server implementation of the service MetricsV1Beta3.MetricsV1Beta3Grpc.MetricsV1Beta3Stub A stub to allow clients to do asynchronous rpc calls to service MetricsV1Beta3.MetricsV1Beta3Settings Settings class to configure an instance ofMetricsV1Beta3Client
.MetricsV1Beta3Settings.Builder Builder for MetricsV1Beta3Settings.MetricUpdate Describes the state of a metric.MetricUpdate.Builder Describes the state of a metric.MountedDataDisk Describes mounted data disk.MountedDataDisk.Builder Describes mounted data disk.Package The packages that must be installed in order for a worker to run the steps of the Cloud Dataflow job that will be assigned to its worker pool.Package.Builder The packages that must be installed in order for a worker to run the steps of the Cloud Dataflow job that will be assigned to its worker pool.ParameterMetadata Metadata for a specific parameter.ParameterMetadata.Builder Metadata for a specific parameter.PipelineDescription A descriptive representation of submitted pipeline as well as the executed form.PipelineDescription.Builder A descriptive representation of submitted pipeline as well as the executed form.ProgressTimeseries Information about the progress of some component of job execution.ProgressTimeseries.Builder Information about the progress of some component of job execution.ProgressTimeseries.Point A point in the timeseries.ProgressTimeseries.Point.Builder A point in the timeseries.PubSubIODetails Metadata for a Pub/Sub connector used by the job.PubSubIODetails.Builder Metadata for a Pub/Sub connector used by the job.PubsubLocation Identifies a pubsub location to use for transferring data into or out of a streaming Dataflow job.PubsubLocation.Builder Identifies a pubsub location to use for transferring data into or out of a streaming Dataflow job.PubsubSnapshotMetadata Represents a Pubsub snapshot.PubsubSnapshotMetadata.Builder Represents a Pubsub snapshot.RuntimeEnvironment The environment values to set at runtime.RuntimeEnvironment.Builder The environment values to set at runtime.RuntimeMetadata RuntimeMetadata describing a runtime environment.RuntimeMetadata.Builder RuntimeMetadata describing a runtime environment.SdkHarnessContainerImage Defines a SDK harness container for executing Dataflow pipelines.SdkHarnessContainerImage.Builder Defines a SDK harness container for executing Dataflow pipelines.SDKInfo SDK Information.SDKInfo.Builder SDK Information.SdkVersion The version of the SDK used to run the job.SdkVersion.Builder The version of the SDK used to run the job.Snapshot Represents a snapshot of a job.Snapshot.Builder Represents a snapshot of a job.SnapshotJobRequest Request to create a snapshot of a job.SnapshotJobRequest.Builder Request to create a snapshot of a job.SnapshotsProto SnapshotsV1Beta3Client Service Description: Provides methods to manage snapshots of Google Cloud Dataflow jobs.SnapshotsV1Beta3Grpc Provides methods to manage snapshots of Google Cloud Dataflow jobs.SnapshotsV1Beta3Grpc.SnapshotsV1Beta3BlockingStub A stub to allow clients to do synchronous rpc calls to service SnapshotsV1Beta3.SnapshotsV1Beta3Grpc.SnapshotsV1Beta3FutureStub A stub to allow clients to do ListenableFuture-style rpc calls to service SnapshotsV1Beta3.SnapshotsV1Beta3Grpc.SnapshotsV1Beta3ImplBase Base class for the server implementation of the service SnapshotsV1Beta3.SnapshotsV1Beta3Grpc.SnapshotsV1Beta3Stub A stub to allow clients to do asynchronous rpc calls to service SnapshotsV1Beta3.SnapshotsV1Beta3Settings Settings class to configure an instance ofSnapshotsV1Beta3Client
.SnapshotsV1Beta3Settings.Builder Builder for SnapshotsV1Beta3Settings.SpannerIODetails Metadata for a Spanner connector used by the job.SpannerIODetails.Builder Metadata for a Spanner connector used by the job.StageExecutionDetails Information about the workers and work items within a stage.StageExecutionDetails.Builder Information about the workers and work items within a stage.StageSummary Information about a particular execution stage of a job.StageSummary.Builder Information about a particular execution stage of a job.StateFamilyConfig State family configuration.StateFamilyConfig.Builder State family configuration.Step Defines a particular step within a Cloud Dataflow job.Step.Builder Defines a particular step within a Cloud Dataflow job.StreamingApplianceSnapshotConfig Streaming appliance snapshot configuration.StreamingApplianceSnapshotConfig.Builder Streaming appliance snapshot configuration.StreamingComputationRanges Describes full or partial data disk assignment information of the computation ranges.StreamingComputationRanges.Builder Describes full or partial data disk assignment information of the computation ranges.StreamingProto StreamingSideInputLocation Identifies the location of a streaming side input.StreamingSideInputLocation.Builder Identifies the location of a streaming side input.StreamingStageLocation Identifies the location of a streaming computation stage, for stage-to-stage communication.StreamingStageLocation.Builder Identifies the location of a streaming computation stage, for stage-to-stage communication.StreamLocation Describes a stream of data, either as input to be processed or as output of a streaming Dataflow job.StreamLocation.Builder Describes a stream of data, either as input to be processed or as output of a streaming Dataflow job.StructuredMessage A rich message format, including a human readable string, a key for identifying the message, and structured data associated with the message for programmatic consumption.StructuredMessage.Builder A rich message format, including a human readable string, a key for identifying the message, and structured data associated with the message for programmatic consumption.StructuredMessage.Parameter Structured data associated with this message.StructuredMessage.Parameter.Builder Structured data associated with this message.TaskRunnerSettings Taskrunner configuration settings.TaskRunnerSettings.Builder Taskrunner configuration settings.TemplateMetadata Metadata describing a template.TemplateMetadata.Builder Metadata describing a template.TemplatesProto TemplatesServiceClient Service Description: Provides a method to create Cloud Dataflow jobs from templates.TemplatesServiceGrpc Provides a method to create Cloud Dataflow jobs from templates.TemplatesServiceGrpc.TemplatesServiceBlockingStub A stub to allow clients to do synchronous rpc calls to service TemplatesService.TemplatesServiceGrpc.TemplatesServiceFutureStub A stub to allow clients to do ListenableFuture-style rpc calls to service TemplatesService.TemplatesServiceGrpc.TemplatesServiceImplBase Base class for the server implementation of the service TemplatesService.TemplatesServiceGrpc.TemplatesServiceStub A stub to allow clients to do asynchronous rpc calls to service TemplatesService.TemplatesServiceSettings Settings class to configure an instance ofTemplatesServiceClient
.TemplatesServiceSettings.Builder Builder for TemplatesServiceSettings.TopologyConfig Global topology of the streaming Dataflow job, including all computations and their sharded locations.TopologyConfig.Builder Global topology of the streaming Dataflow job, including all computations and their sharded locations.TransformSummary Description of the type, names/ids, and input/outputs for a transform.TransformSummary.Builder Description of the type, names/ids, and input/outputs for a transform.UpdateJobRequest Request to update a Cloud Dataflow job.UpdateJobRequest.Builder Request to update a Cloud Dataflow job.WorkerDetails Information about a workerWorkerDetails.Builder Information about a workerWorkerPool Describes one particular pool of Cloud Dataflow workers to be instantiated by the Cloud Dataflow service in order to perform the computations required by a job.WorkerPool.Builder Describes one particular pool of Cloud Dataflow workers to be instantiated by the Cloud Dataflow service in order to perform the computations required by a job.WorkerSettings Provides data to pass through to the worker harness.WorkerSettings.Builder Provides data to pass through to the worker harness.WorkItemDetails Information about an individual work item execution.WorkItemDetails.Builder Information about an individual work item execution. -
Enum Summary Enum Description AutoscalingAlgorithm Specifies the algorithm used to determine the number of worker processes to run at any given point in time, based on the amount of data left to process, the number of workers, and how quickly existing workers are processing data.AutoscalingEvent.AutoscalingEventType Indicates the type of autoscaling event.CreateJobFromTemplateRequest.TemplateCase DefaultPackageSet The default set of packages to be staged on a pool of workers.DisplayData.ValueCase ExecutionState The state of some component of job execution.FlexResourceSchedulingGoal Specifies the resource to optimize for in Flexible Resource Scheduling.GetTemplateRequest.TemplateCase GetTemplateRequest.TemplateView The various views of a template that may be retrieved.GetTemplateResponse.TemplateType Template Type.JobMessageImportance Indicates the importance of the message.JobState Describes the overall state of a [google.dataflow.v1beta3.Job][google.dataflow.v1beta3.Job].JobType Specifies the processing model used by a [google.dataflow.v1beta3.Job], which determines the way the Job is managed by the Cloud Dataflow service (how workers are scheduled, how inputs are sharded, etc).JobView Selector for how much information is returned in Job responses.KindType Type of transform or stage operation.LaunchFlexTemplateParameter.TemplateCase LaunchTemplateRequest.TemplateCase ListJobsRequest.Filter This field filters out and returns jobs in the specified job state.ParameterType ParameterType specifies what kind of input we need for this parameter.SDKInfo.Language SDK Language.SdkVersion.SdkSupportStatus The support status of the SDK used to run the job.ShuffleMode Specifies the shuffle mode used by a [google.dataflow.v1beta3.Job], which determines the approach data is shuffled during processing.SnapshotState Snapshot state.StreamLocation.LocationCase TeardownPolicy Specifies what happens to a resource when a Cloud Dataflow [google.dataflow.v1beta3.Job][google.dataflow.v1beta3.Job] has completed.WorkerIPAddressConfiguration Specifies how IP addresses should be allocated to the worker machines.