dataflow

package
v0.0.0-...-de2eba5 Latest Latest
Warning

This package is not in the latest version of its module.

Go to latest
Published: May 19, 2015 License: BSD-3-Clause Imports: 11 Imported by: 0

Documentation

Overview

Package dataflow provides access to the Google Dataflow API.

Usage example:

import "google.golang.org/api/dataflow/v1beta3"
...
dataflowService, err := dataflow.New(oauthHttpClient)

Index

Constants

View Source
const (
	// View and manage your data across Google Cloud Platform services
	CloudPlatformScope = "https://www.googleapis.com/auth/cloud-platform"

	// View your email address
	UserinfoEmailScope = "https://www.googleapis.com/auth/userinfo.email"
)

OAuth2 scopes used by this API.

Variables

This section is empty.

Functions

This section is empty.

Types

type ApproximateProgress

type ApproximateProgress struct {
	PercentComplete float64 `json:"percentComplete,omitempty"`

	Position *Position `json:"position,omitempty"`

	RemainingTime string `json:"remainingTime,omitempty"`
}

type AutoscalingSettings

type AutoscalingSettings struct {
	// Possible values:
	//   "AUTOSCALING_ALGORITHM_BASIC"
	//   "AUTOSCALING_ALGORITHM_NONE"
	//   "AUTOSCALING_ALGORITHM_UNKNOWN"
	Algorithm string `json:"algorithm,omitempty"`

	MaxNumWorkers int64 `json:"maxNumWorkers,omitempty"`
}

type ComputationTopology

type ComputationTopology struct {
	ComputationId string `json:"computationId,omitempty"`

	Inputs []*StreamLocation `json:"inputs,omitempty"`

	KeyRanges []*KeyRangeLocation `json:"keyRanges,omitempty"`

	Outputs []*StreamLocation `json:"outputs,omitempty"`
}

type DataDiskAssignment

type DataDiskAssignment struct {
	DataDisks []string `json:"dataDisks,omitempty"`

	VmInstance string `json:"vmInstance,omitempty"`
}

type DerivedSource

type DerivedSource struct {
	// Possible values:
	//   "SOURCE_DERIVATION_MODE_CHILD_OF_CURRENT"
	//   "SOURCE_DERIVATION_MODE_INDEPENDENT"
	//   "SOURCE_DERIVATION_MODE_SIBLING_OF_CURRENT"
	//   "SOURCE_DERIVATION_MODE_UNKNOWN"
	DerivationMode string `json:"derivationMode,omitempty"`

	Source *Source `json:"source,omitempty"`
}

type Disk

type Disk struct {
	DiskType string `json:"diskType,omitempty"`

	MountPoint string `json:"mountPoint,omitempty"`

	SizeGb int64 `json:"sizeGb,omitempty"`
}

type DynamicSourceSplit

type DynamicSourceSplit struct {
	Primary *DerivedSource `json:"primary,omitempty"`

	Residual *DerivedSource `json:"residual,omitempty"`
}

type Environment

type Environment struct {
	ClusterManagerApiService string `json:"clusterManagerApiService,omitempty"`

	Dataset string `json:"dataset,omitempty"`

	Experiments []string `json:"experiments,omitempty"`

	SdkPipelineOptions EnvironmentSdkPipelineOptions `json:"sdkPipelineOptions,omitempty"`

	TempStoragePrefix string `json:"tempStoragePrefix,omitempty"`

	UserAgent EnvironmentUserAgent `json:"userAgent,omitempty"`

	Version EnvironmentVersion `json:"version,omitempty"`

	WorkerPools []*WorkerPool `json:"workerPools,omitempty"`
}

type EnvironmentSdkPipelineOptions

type EnvironmentSdkPipelineOptions interface{}

type EnvironmentUserAgent

type EnvironmentUserAgent interface{}

type EnvironmentVersion

type EnvironmentVersion interface{}

type FlattenInstruction

type FlattenInstruction struct {
	Inputs []*InstructionInput `json:"inputs,omitempty"`
}

type GoogleprotobufValue

type GoogleprotobufValue interface{}

type InstructionInput

type InstructionInput struct {
	OutputNum int64 `json:"outputNum,omitempty"`

	ProducerInstructionIndex int64 `json:"producerInstructionIndex,omitempty"`
}

type InstructionOutput

type InstructionOutput struct {
	Codec InstructionOutputCodec `json:"codec,omitempty"`

	Name string `json:"name,omitempty"`
}

type InstructionOutputCodec

type InstructionOutputCodec interface{}

type Job

type Job struct {
	CreateTime string `json:"createTime,omitempty"`

	// Possible values:
	//   "JOB_STATE_CANCELLED"
	//   "JOB_STATE_DONE"
	//   "JOB_STATE_FAILED"
	//   "JOB_STATE_RUNNING"
	//   "JOB_STATE_STOPPED"
	//   "JOB_STATE_UNKNOWN"
	CurrentState string `json:"currentState,omitempty"`

	CurrentStateTime string `json:"currentStateTime,omitempty"`

	Environment *Environment `json:"environment,omitempty"`

	ExecutionInfo *JobExecutionInfo `json:"executionInfo,omitempty"`

	Id string `json:"id,omitempty"`

	Name string `json:"name,omitempty"`

	ProjectId string `json:"projectId,omitempty"`

	// Possible values:
	//   "JOB_STATE_CANCELLED"
	//   "JOB_STATE_DONE"
	//   "JOB_STATE_FAILED"
	//   "JOB_STATE_RUNNING"
	//   "JOB_STATE_STOPPED"
	//   "JOB_STATE_UNKNOWN"
	RequestedState string `json:"requestedState,omitempty"`

	Steps []*Step `json:"steps,omitempty"`

	// Possible values:
	//   "JOB_TYPE_BATCH"
	//   "JOB_TYPE_STREAMING"
	//   "JOB_TYPE_UNKNOWN"
	Type string `json:"type,omitempty"`
}

type JobExecutionInfo

type JobExecutionInfo struct {
	Stages map[string]JobExecutionStageInfo `json:"stages,omitempty"`
}

type JobExecutionStageInfo

type JobExecutionStageInfo struct {
	StepName []string `json:"stepName,omitempty"`
}

type JobMessage

type JobMessage struct {
	Id string `json:"id,omitempty"`

	// Possible values:
	//   "JOB_MESSAGE_DEBUG"
	//   "JOB_MESSAGE_DETAILED"
	//   "JOB_MESSAGE_ERROR"
	//   "JOB_MESSAGE_IMPORTANCE_UNKNOWN"
	//   "JOB_MESSAGE_WARNING"
	MessageImportance string `json:"messageImportance,omitempty"`

	MessageText string `json:"messageText,omitempty"`

	Time string `json:"time,omitempty"`
}

type JobMetrics

type JobMetrics struct {
	MetricTime string `json:"metricTime,omitempty"`

	Metrics []*MetricUpdate `json:"metrics,omitempty"`
}

type KeyRangeDataDiskAssignment

type KeyRangeDataDiskAssignment struct {
	DataDisk string `json:"dataDisk,omitempty"`

	End string `json:"end,omitempty"`

	Start string `json:"start,omitempty"`
}

type KeyRangeLocation

type KeyRangeLocation struct {
	DataDisk string `json:"dataDisk,omitempty"`

	DeliveryEndpoint string `json:"deliveryEndpoint,omitempty"`

	End string `json:"end,omitempty"`

	PersistentDirectory string `json:"persistentDirectory,omitempty"`

	Start string `json:"start,omitempty"`
}

type LeaseWorkItemRequest

type LeaseWorkItemRequest struct {
	CurrentWorkerTime string `json:"currentWorkerTime,omitempty"`

	RequestedLeaseDuration string `json:"requestedLeaseDuration,omitempty"`

	WorkItemTypes []string `json:"workItemTypes,omitempty"`

	WorkerCapabilities []string `json:"workerCapabilities,omitempty"`

	WorkerId string `json:"workerId,omitempty"`
}

type LeaseWorkItemResponse

type LeaseWorkItemResponse struct {
	WorkItems []*WorkItem `json:"workItems,omitempty"`
}

type ListJobMessagesResponse

type ListJobMessagesResponse struct {
	JobMessages []*JobMessage `json:"jobMessages,omitempty"`

	NextPageToken string `json:"nextPageToken,omitempty"`
}

type ListJobsResponse

type ListJobsResponse struct {
	Jobs []*Job `json:"jobs,omitempty"`

	NextPageToken string `json:"nextPageToken,omitempty"`
}

type MapTask

type MapTask struct {
	Instructions []*ParallelInstruction `json:"instructions,omitempty"`

	StageName string `json:"stageName,omitempty"`

	SystemName string `json:"systemName,omitempty"`
}

type MetricStructuredName

type MetricStructuredName struct {
	Context map[string]string `json:"context,omitempty"`

	Name string `json:"name,omitempty"`

	Origin string `json:"origin,omitempty"`
}

type MetricUpdate

type MetricUpdate struct {
	Cumulative *bool `json:"cumulative,omitempty"`

	Internal interface{} `json:"internal,omitempty"`

	Kind string `json:"kind,omitempty"`

	MeanCount interface{} `json:"meanCount,omitempty"`

	MeanSum interface{} `json:"meanSum,omitempty"`

	Name *MetricStructuredName `json:"name,omitempty"`

	Scalar interface{} `json:"scalar,omitempty"`

	Set interface{} `json:"set,omitempty"`

	UpdateTime string `json:"updateTime,omitempty"`
}

type MountedDataDisk

type MountedDataDisk struct {
	DataDisk string `json:"dataDisk,omitempty"`
}

type MultiOutputInfo

type MultiOutputInfo struct {
	Tag string `json:"tag,omitempty"`
}

type Package

type Package struct {
	Location string `json:"location,omitempty"`

	Name string `json:"name,omitempty"`
}

type ParDoInstruction

type ParDoInstruction struct {
	Input *InstructionInput `json:"input,omitempty"`

	MultiOutputInfos []*MultiOutputInfo `json:"multiOutputInfos,omitempty"`

	NumOutputs int64 `json:"numOutputs,omitempty"`

	SideInputs []*SideInputInfo `json:"sideInputs,omitempty"`

	UserFn ParDoInstructionUserFn `json:"userFn,omitempty"`
}

type ParDoInstructionUserFn

type ParDoInstructionUserFn interface{}

type ParallelInstruction

type ParallelInstruction struct {
	Flatten *FlattenInstruction `json:"flatten,omitempty"`

	Name string `json:"name,omitempty"`

	Outputs []*InstructionOutput `json:"outputs,omitempty"`

	ParDo *ParDoInstruction `json:"parDo,omitempty"`

	PartialGroupByKey *PartialGroupByKeyInstruction `json:"partialGroupByKey,omitempty"`

	Read *ReadInstruction `json:"read,omitempty"`

	SystemName string `json:"systemName,omitempty"`

	Write *WriteInstruction `json:"write,omitempty"`
}

type PartialGroupByKeyInstruction

type PartialGroupByKeyInstruction struct {
	Input *InstructionInput `json:"input,omitempty"`

	InputElementCodec PartialGroupByKeyInstructionInputElementCodec `json:"inputElementCodec,omitempty"`

	ValueCombiningFn PartialGroupByKeyInstructionValueCombiningFn `json:"valueCombiningFn,omitempty"`
}

type PartialGroupByKeyInstructionInputElementCodec

type PartialGroupByKeyInstructionInputElementCodec interface{}

type PartialGroupByKeyInstructionValueCombiningFn

type PartialGroupByKeyInstructionValueCombiningFn interface{}

type Position

type Position struct {
	ByteOffset int64 `json:"byteOffset,omitempty,string"`

	End *bool `json:"end,omitempty"`

	Key string `json:"key,omitempty"`

	RecordIndex int64 `json:"recordIndex,omitempty,string"`

	ShufflePosition string `json:"shufflePosition,omitempty"`
}

type PubsubLocation

type PubsubLocation struct {
	DropLateData *bool `json:"dropLateData,omitempty"`

	IdLabel string `json:"idLabel,omitempty"`

	Subscription string `json:"subscription,omitempty"`

	TimestampLabel string `json:"timestampLabel,omitempty"`

	Topic string `json:"topic,omitempty"`

	TrackingSubscription string `json:"trackingSubscription,omitempty"`
}

type ReadInstruction

type ReadInstruction struct {
	Source *Source `json:"source,omitempty"`
}

type ReportWorkItemStatusRequest

type ReportWorkItemStatusRequest struct {
	CurrentWorkerTime string `json:"currentWorkerTime,omitempty"`

	WorkItemStatuses []*WorkItemStatus `json:"workItemStatuses,omitempty"`

	WorkerId string `json:"workerId,omitempty"`
}

type ReportWorkItemStatusResponse

type ReportWorkItemStatusResponse struct {
	WorkItemServiceStates []*WorkItemServiceState `json:"workItemServiceStates,omitempty"`
}

type SeqMapTask

type SeqMapTask struct {
	Inputs []*SideInputInfo `json:"inputs,omitempty"`

	Name string `json:"name,omitempty"`

	OutputInfos []*SeqMapTaskOutputInfo `json:"outputInfos,omitempty"`

	StageName string `json:"stageName,omitempty"`

	SystemName string `json:"systemName,omitempty"`

	UserFn SeqMapTaskUserFn `json:"userFn,omitempty"`
}

type SeqMapTaskOutputInfo

type SeqMapTaskOutputInfo struct {
	Sink *Sink `json:"sink,omitempty"`

	Tag string `json:"tag,omitempty"`
}

type SeqMapTaskUserFn

type SeqMapTaskUserFn interface{}

type Service

type Service struct {
	BasePath  string // API endpoint base URL
	UserAgent string // optional additional User-Agent fragment

	V1b3 *V1b3Service
	// contains filtered or unexported fields
}

func New

func New(client *http.Client) (*Service, error)

type ShellTask

type ShellTask struct {
	Command string `json:"command,omitempty"`

	ExitCode int64 `json:"exitCode,omitempty"`
}

type SideInputInfo

type SideInputInfo struct {
	Kind SideInputInfoKind `json:"kind,omitempty"`

	Sources []*Source `json:"sources,omitempty"`

	Tag string `json:"tag,omitempty"`
}

type SideInputInfoKind

type SideInputInfoKind interface{}

type Sink

type Sink struct {
	Codec SinkCodec `json:"codec,omitempty"`

	Spec SinkSpec `json:"spec,omitempty"`
}

type SinkCodec

type SinkCodec interface{}

type SinkSpec

type SinkSpec interface{}

type Source

type Source struct {
	BaseSpecs []SourceBaseSpecs `json:"baseSpecs,omitempty"`

	Codec SourceCodec `json:"codec,omitempty"`

	DoesNotNeedSplitting *bool `json:"doesNotNeedSplitting,omitempty"`

	Metadata *SourceMetadata `json:"metadata,omitempty"`

	Spec SourceSpec `json:"spec,omitempty"`
}

type SourceBaseSpecs

type SourceBaseSpecs interface{}

type SourceCodec

type SourceCodec interface{}

type SourceFork

type SourceFork struct {
	Primary *SourceSplitShard `json:"primary,omitempty"`

	PrimarySource *DerivedSource `json:"primarySource,omitempty"`

	Residual *SourceSplitShard `json:"residual,omitempty"`

	ResidualSource *DerivedSource `json:"residualSource,omitempty"`
}

type SourceGetMetadataRequest

type SourceGetMetadataRequest struct {
	Source *Source `json:"source,omitempty"`
}

type SourceGetMetadataResponse

type SourceGetMetadataResponse struct {
	Metadata *SourceMetadata `json:"metadata,omitempty"`
}

type SourceMetadata

type SourceMetadata struct {
	EstimatedSizeBytes int64 `json:"estimatedSizeBytes,omitempty,string"`

	Infinite *bool `json:"infinite,omitempty"`

	ProducesSortedKeys *bool `json:"producesSortedKeys,omitempty"`
}

type SourceOperationRequest

type SourceOperationRequest struct {
	GetMetadata *SourceGetMetadataRequest `json:"getMetadata,omitempty"`

	Split *SourceSplitRequest `json:"split,omitempty"`
}

type SourceOperationResponse

type SourceOperationResponse struct {
	GetMetadata *SourceGetMetadataResponse `json:"getMetadata,omitempty"`

	Split *SourceSplitResponse `json:"split,omitempty"`
}

type SourceSpec

type SourceSpec interface{}

type SourceSplitOptions

type SourceSplitOptions struct {
	DesiredBundleSizeBytes int64 `json:"desiredBundleSizeBytes,omitempty,string"`

	DesiredShardSizeBytes int64 `json:"desiredShardSizeBytes,omitempty,string"`
}

type SourceSplitRequest

type SourceSplitRequest struct {
	Options *SourceSplitOptions `json:"options,omitempty"`

	Source *Source `json:"source,omitempty"`
}

type SourceSplitResponse

type SourceSplitResponse struct {
	Bundles []*DerivedSource `json:"bundles,omitempty"`

	// Possible values:
	//   "SOURCE_SPLIT_OUTCOME_SPLITTING_HAPPENED"
	//   "SOURCE_SPLIT_OUTCOME_UNKNOWN"
	//   "SOURCE_SPLIT_OUTCOME_USE_CURRENT"
	Outcome string `json:"outcome,omitempty"`

	Shards []*SourceSplitShard `json:"shards,omitempty"`
}

type SourceSplitShard

type SourceSplitShard struct {
	// Possible values:
	//   "SOURCE_DERIVATION_MODE_CHILD_OF_CURRENT"
	//   "SOURCE_DERIVATION_MODE_INDEPENDENT"
	//   "SOURCE_DERIVATION_MODE_SIBLING_OF_CURRENT"
	//   "SOURCE_DERIVATION_MODE_UNKNOWN"
	DerivationMode string `json:"derivationMode,omitempty"`

	Source *Source `json:"source,omitempty"`
}

type Status

type Status struct {
	Code int64 `json:"code,omitempty"`

	Details []StatusDetails `json:"details,omitempty"`

	Message string `json:"message,omitempty"`
}

type StatusDetails

type StatusDetails interface{}

type Step

type Step struct {
	Kind string `json:"kind,omitempty"`

	Name string `json:"name,omitempty"`

	Properties StepProperties `json:"properties,omitempty"`
}

type StepProperties

type StepProperties interface{}

type StreamLocation

type StreamLocation struct {
	PubsubLocation *PubsubLocation `json:"pubsubLocation,omitempty"`

	SideInputLocation *StreamingSideInputLocation `json:"sideInputLocation,omitempty"`

	StreamingStageLocation *StreamingStageLocation `json:"streamingStageLocation,omitempty"`
}

type StreamingComputationRanges

type StreamingComputationRanges struct {
	ComputationId string `json:"computationId,omitempty"`

	RangeAssignments []*KeyRangeDataDiskAssignment `json:"rangeAssignments,omitempty"`
}

type StreamingComputationTask

type StreamingComputationTask struct {
	ComputationRanges []*StreamingComputationRanges `json:"computationRanges,omitempty"`

	DataDisks []*MountedDataDisk `json:"dataDisks,omitempty"`

	// Possible values:
	//   "STREAMING_COMPUTATION_TASK_START"
	//   "STREAMING_COMPUTATION_TASK_STOP"
	//   "STREAMING_COMPUTATION_TASK_UNKNOWN"
	TaskType string `json:"taskType,omitempty"`
}

type StreamingSetupTask

type StreamingSetupTask struct {
	ReceiveWorkPort int64 `json:"receiveWorkPort,omitempty"`

	StreamingComputationTopology *TopologyConfig `json:"streamingComputationTopology,omitempty"`

	WorkerHarnessPort int64 `json:"workerHarnessPort,omitempty"`
}

type StreamingSideInputLocation

type StreamingSideInputLocation struct {
	Tag string `json:"tag,omitempty"`
}

type StreamingStageLocation

type StreamingStageLocation struct {
	StreamId string `json:"streamId,omitempty"`
}

type TaskRunnerSettings

type TaskRunnerSettings struct {
	Alsologtostderr *bool `json:"alsologtostderr,omitempty"`

	BaseTaskDir string `json:"baseTaskDir,omitempty"`

	BaseUrl string `json:"baseUrl,omitempty"`

	CommandlinesFileName string `json:"commandlinesFileName,omitempty"`

	ContinueOnException *bool `json:"continueOnException,omitempty"`

	DataflowApiVersion string `json:"dataflowApiVersion,omitempty"`

	HarnessCommand string `json:"harnessCommand,omitempty"`

	LanguageHint string `json:"languageHint,omitempty"`

	LogDir string `json:"logDir,omitempty"`

	LogToSerialconsole *bool `json:"logToSerialconsole,omitempty"`

	LogUploadLocation string `json:"logUploadLocation,omitempty"`

	OauthScopes []string `json:"oauthScopes,omitempty"`

	ParallelWorkerSettings *WorkerSettings `json:"parallelWorkerSettings,omitempty"`

	StreamingWorkerMainClass string `json:"streamingWorkerMainClass,omitempty"`

	TaskGroup string `json:"taskGroup,omitempty"`

	TaskUser string `json:"taskUser,omitempty"`

	TempStoragePrefix string `json:"tempStoragePrefix,omitempty"`

	VmId string `json:"vmId,omitempty"`

	WorkflowFileName string `json:"workflowFileName,omitempty"`
}

type TopologyConfig

type TopologyConfig struct {
	Computations []*ComputationTopology `json:"computations,omitempty"`

	DataDiskAssignments []*DataDiskAssignment `json:"dataDiskAssignments,omitempty"`
}

type V1b3ProjectsJobsCreateCall

type V1b3ProjectsJobsCreateCall struct {
	// contains filtered or unexported fields
}

func (*V1b3ProjectsJobsCreateCall) Do

func (c *V1b3ProjectsJobsCreateCall) Do() (*Job, error)

func (*V1b3ProjectsJobsCreateCall) Fields

Fields allows partial responses to be retrieved. See https://developers.google.com/gdata/docs/2.0/basics#PartialResponse for more information.

func (*V1b3ProjectsJobsCreateCall) ReplaceJobId

func (c *V1b3ProjectsJobsCreateCall) ReplaceJobId(replaceJobId string) *V1b3ProjectsJobsCreateCall

ReplaceJobId sets the optional parameter "replaceJobId":

func (*V1b3ProjectsJobsCreateCall) View

View sets the optional parameter "view":

Possible values:

"JOB_VIEW_ALL"
"JOB_VIEW_SUMMARY"
"JOB_VIEW_UNKNOWN"

type V1b3ProjectsJobsGetCall

type V1b3ProjectsJobsGetCall struct {
	// contains filtered or unexported fields
}

func (*V1b3ProjectsJobsGetCall) Do

func (c *V1b3ProjectsJobsGetCall) Do() (*Job, error)

func (*V1b3ProjectsJobsGetCall) Fields

Fields allows partial responses to be retrieved. See https://developers.google.com/gdata/docs/2.0/basics#PartialResponse for more information.

func (*V1b3ProjectsJobsGetCall) View

View sets the optional parameter "view":

Possible values:

"JOB_VIEW_ALL"
"JOB_VIEW_SUMMARY"
"JOB_VIEW_UNKNOWN"

type V1b3ProjectsJobsGetMetricsCall

type V1b3ProjectsJobsGetMetricsCall struct {
	// contains filtered or unexported fields
}

func (*V1b3ProjectsJobsGetMetricsCall) Do

func (*V1b3ProjectsJobsGetMetricsCall) Fields

Fields allows partial responses to be retrieved. See https://developers.google.com/gdata/docs/2.0/basics#PartialResponse for more information.

func (*V1b3ProjectsJobsGetMetricsCall) StartTime

StartTime sets the optional parameter "startTime":

type V1b3ProjectsJobsListCall

type V1b3ProjectsJobsListCall struct {
	// contains filtered or unexported fields
}

func (*V1b3ProjectsJobsListCall) Do

func (*V1b3ProjectsJobsListCall) Fields

Fields allows partial responses to be retrieved. See https://developers.google.com/gdata/docs/2.0/basics#PartialResponse for more information.

func (*V1b3ProjectsJobsListCall) PageSize

PageSize sets the optional parameter "pageSize":

func (*V1b3ProjectsJobsListCall) PageToken

func (c *V1b3ProjectsJobsListCall) PageToken(pageToken string) *V1b3ProjectsJobsListCall

PageToken sets the optional parameter "pageToken":

func (*V1b3ProjectsJobsListCall) View

View sets the optional parameter "view":

Possible values:

"JOB_VIEW_ALL"
"JOB_VIEW_SUMMARY"
"JOB_VIEW_UNKNOWN"

type V1b3ProjectsJobsMessagesListCall

type V1b3ProjectsJobsMessagesListCall struct {
	// contains filtered or unexported fields
}

func (*V1b3ProjectsJobsMessagesListCall) Do

func (*V1b3ProjectsJobsMessagesListCall) EndTime

EndTime sets the optional parameter "endTime":

func (*V1b3ProjectsJobsMessagesListCall) Fields

Fields allows partial responses to be retrieved. See https://developers.google.com/gdata/docs/2.0/basics#PartialResponse for more information.

func (*V1b3ProjectsJobsMessagesListCall) MinimumImportance

func (c *V1b3ProjectsJobsMessagesListCall) MinimumImportance(minimumImportance string) *V1b3ProjectsJobsMessagesListCall

MinimumImportance sets the optional parameter "minimumImportance":

Possible values:

"JOB_MESSAGE_DEBUG"
"JOB_MESSAGE_DETAILED"
"JOB_MESSAGE_ERROR"
"JOB_MESSAGE_IMPORTANCE_UNKNOWN"
"JOB_MESSAGE_WARNING"

func (*V1b3ProjectsJobsMessagesListCall) PageSize

PageSize sets the optional parameter "pageSize":

func (*V1b3ProjectsJobsMessagesListCall) PageToken

PageToken sets the optional parameter "pageToken":

func (*V1b3ProjectsJobsMessagesListCall) StartTime

StartTime sets the optional parameter "startTime":

type V1b3ProjectsJobsMessagesService

type V1b3ProjectsJobsMessagesService struct {
	// contains filtered or unexported fields
}

func NewV1b3ProjectsJobsMessagesService

func NewV1b3ProjectsJobsMessagesService(s *Service) *V1b3ProjectsJobsMessagesService

func (*V1b3ProjectsJobsMessagesService) List

List: Request the job status.

type V1b3ProjectsJobsPatchCall

type V1b3ProjectsJobsPatchCall struct {
	// contains filtered or unexported fields
}

func (*V1b3ProjectsJobsPatchCall) Do

func (c *V1b3ProjectsJobsPatchCall) Do() (*Job, error)

func (*V1b3ProjectsJobsPatchCall) Fields

Fields allows partial responses to be retrieved. See https://developers.google.com/gdata/docs/2.0/basics#PartialResponse for more information.

type V1b3ProjectsJobsService

type V1b3ProjectsJobsService struct {
	Messages *V1b3ProjectsJobsMessagesService

	WorkItems *V1b3ProjectsJobsWorkItemsService
	// contains filtered or unexported fields
}

func NewV1b3ProjectsJobsService

func NewV1b3ProjectsJobsService(s *Service) *V1b3ProjectsJobsService

func (*V1b3ProjectsJobsService) Create

func (r *V1b3ProjectsJobsService) Create(projectId string, job *Job) *V1b3ProjectsJobsCreateCall

Create: Creates a dataflow job.

func (*V1b3ProjectsJobsService) Get

Get: Gets the state of the specified dataflow job.

func (*V1b3ProjectsJobsService) GetMetrics

func (r *V1b3ProjectsJobsService) GetMetrics(projectId string, jobId string) *V1b3ProjectsJobsGetMetricsCall

GetMetrics: Request the job status.

func (*V1b3ProjectsJobsService) List

List: List the jobs of a project

func (*V1b3ProjectsJobsService) Patch

func (r *V1b3ProjectsJobsService) Patch(projectId string, jobId string, job *Job) *V1b3ProjectsJobsPatchCall

Patch: Updates the state of an existing dataflow job. This method supports patch semantics.

func (*V1b3ProjectsJobsService) Update

func (r *V1b3ProjectsJobsService) Update(projectId string, jobId string, job *Job) *V1b3ProjectsJobsUpdateCall

Update: Updates the state of an existing dataflow job.

type V1b3ProjectsJobsUpdateCall

type V1b3ProjectsJobsUpdateCall struct {
	// contains filtered or unexported fields
}

func (*V1b3ProjectsJobsUpdateCall) Do

func (c *V1b3ProjectsJobsUpdateCall) Do() (*Job, error)

func (*V1b3ProjectsJobsUpdateCall) Fields

Fields allows partial responses to be retrieved. See https://developers.google.com/gdata/docs/2.0/basics#PartialResponse for more information.

type V1b3ProjectsJobsWorkItemsLeaseCall

type V1b3ProjectsJobsWorkItemsLeaseCall struct {
	// contains filtered or unexported fields
}

func (*V1b3ProjectsJobsWorkItemsLeaseCall) Do

func (*V1b3ProjectsJobsWorkItemsLeaseCall) Fields

Fields allows partial responses to be retrieved. See https://developers.google.com/gdata/docs/2.0/basics#PartialResponse for more information.

type V1b3ProjectsJobsWorkItemsReportStatusCall

type V1b3ProjectsJobsWorkItemsReportStatusCall struct {
	// contains filtered or unexported fields
}

func (*V1b3ProjectsJobsWorkItemsReportStatusCall) Do

func (*V1b3ProjectsJobsWorkItemsReportStatusCall) Fields

Fields allows partial responses to be retrieved. See https://developers.google.com/gdata/docs/2.0/basics#PartialResponse for more information.

type V1b3ProjectsJobsWorkItemsService

type V1b3ProjectsJobsWorkItemsService struct {
	// contains filtered or unexported fields
}

func NewV1b3ProjectsJobsWorkItemsService

func NewV1b3ProjectsJobsWorkItemsService(s *Service) *V1b3ProjectsJobsWorkItemsService

func (*V1b3ProjectsJobsWorkItemsService) Lease

Lease: Leases a dataflow WorkItem to run.

func (*V1b3ProjectsJobsWorkItemsService) ReportStatus

func (r *V1b3ProjectsJobsWorkItemsService) ReportStatus(projectId string, jobId string, reportworkitemstatusrequest *ReportWorkItemStatusRequest) *V1b3ProjectsJobsWorkItemsReportStatusCall

ReportStatus: Reports the status of dataflow WorkItems leased by a worker.

type V1b3ProjectsService

type V1b3ProjectsService struct {
	Jobs *V1b3ProjectsJobsService
	// contains filtered or unexported fields
}

func NewV1b3ProjectsService

func NewV1b3ProjectsService(s *Service) *V1b3ProjectsService

type V1b3Service

type V1b3Service struct {
	Projects *V1b3ProjectsService
	// contains filtered or unexported fields
}

func NewV1b3Service

func NewV1b3Service(s *Service) *V1b3Service

type WorkItem

type WorkItem struct {
	Configuration string `json:"configuration,omitempty"`

	Id int64 `json:"id,omitempty,string"`

	InitialReportIndex int64 `json:"initialReportIndex,omitempty,string"`

	JobId string `json:"jobId,omitempty"`

	LeaseExpireTime string `json:"leaseExpireTime,omitempty"`

	MapTask *MapTask `json:"mapTask,omitempty"`

	Packages []*Package `json:"packages,omitempty"`

	ProjectId string `json:"projectId,omitempty"`

	ReportStatusInterval string `json:"reportStatusInterval,omitempty"`

	SeqMapTask *SeqMapTask `json:"seqMapTask,omitempty"`

	ShellTask *ShellTask `json:"shellTask,omitempty"`

	SourceOperationTask *SourceOperationRequest `json:"sourceOperationTask,omitempty"`

	StreamingComputationTask *StreamingComputationTask `json:"streamingComputationTask,omitempty"`

	StreamingSetupTask *StreamingSetupTask `json:"streamingSetupTask,omitempty"`
}

type WorkItemServiceState

type WorkItemServiceState struct {
	HarnessData WorkItemServiceStateHarnessData `json:"harnessData,omitempty"`

	LeaseExpireTime string `json:"leaseExpireTime,omitempty"`

	NextReportIndex int64 `json:"nextReportIndex,omitempty,string"`

	ReportStatusInterval string `json:"reportStatusInterval,omitempty"`

	SuggestedStopPoint *ApproximateProgress `json:"suggestedStopPoint,omitempty"`

	SuggestedStopPosition *Position `json:"suggestedStopPosition,omitempty"`
}

type WorkItemServiceStateHarnessData

type WorkItemServiceStateHarnessData interface{}

type WorkItemStatus

type WorkItemStatus struct {
	Completed *bool `json:"completed,omitempty"`

	DynamicSourceSplit *DynamicSourceSplit `json:"dynamicSourceSplit,omitempty"`

	Errors []*Status `json:"errors,omitempty"`

	MetricUpdates []*MetricUpdate `json:"metricUpdates,omitempty"`

	Progress *ApproximateProgress `json:"progress,omitempty"`

	ReportIndex int64 `json:"reportIndex,omitempty,string"`

	RequestedLeaseDuration string `json:"requestedLeaseDuration,omitempty"`

	SourceFork *SourceFork `json:"sourceFork,omitempty"`

	SourceOperationResponse *SourceOperationResponse `json:"sourceOperationResponse,omitempty"`

	StopPosition *Position `json:"stopPosition,omitempty"`

	WorkItemId string `json:"workItemId,omitempty"`
}

type WorkerPool

type WorkerPool struct {
	AutoscalingSettings *AutoscalingSettings `json:"autoscalingSettings,omitempty"`

	DataDisks []*Disk `json:"dataDisks,omitempty"`

	// Possible values:
	//   "DEFAULT_PACKAGE_SET_JAVA"
	//   "DEFAULT_PACKAGE_SET_NONE"
	//   "DEFAULT_PACKAGE_SET_PYTHON"
	//   "DEFAULT_PACKAGE_SET_UNKNOWN"
	DefaultPackageSet string `json:"defaultPackageSet,omitempty"`

	DiskSizeGb int64 `json:"diskSizeGb,omitempty"`

	DiskSourceImage string `json:"diskSourceImage,omitempty"`

	DiskType string `json:"diskType,omitempty"`

	Kind string `json:"kind,omitempty"`

	MachineType string `json:"machineType,omitempty"`

	Metadata map[string]string `json:"metadata,omitempty"`

	NumWorkers int64 `json:"numWorkers,omitempty"`

	OnHostMaintenance string `json:"onHostMaintenance,omitempty"`

	Packages []*Package `json:"packages,omitempty"`

	PoolArgs WorkerPoolPoolArgs `json:"poolArgs,omitempty"`

	TaskrunnerSettings *TaskRunnerSettings `json:"taskrunnerSettings,omitempty"`

	// Possible values:
	//   "TEARDOWN_ALWAYS"
	//   "TEARDOWN_NEVER"
	//   "TEARDOWN_ON_SUCCESS"
	//   "TEARDOWN_POLICY_UNKNOWN"
	TeardownPolicy string `json:"teardownPolicy,omitempty"`

	Zone string `json:"zone,omitempty"`
}

type WorkerPoolPoolArgs

type WorkerPoolPoolArgs interface{}

type WorkerSettings

type WorkerSettings struct {
	BaseUrl string `json:"baseUrl,omitempty"`

	ReportingEnabled *bool `json:"reportingEnabled,omitempty"`

	ServicePath string `json:"servicePath,omitempty"`

	ShuffleServicePath string `json:"shuffleServicePath,omitempty"`

	TempStoragePrefix string `json:"tempStoragePrefix,omitempty"`

	WorkerId string `json:"workerId,omitempty"`
}

type WriteInstruction

type WriteInstruction struct {
	Input *InstructionInput `json:"input,omitempty"`

	Sink *Sink `json:"sink,omitempty"`
}

Jump to

Keyboard shortcuts

? : This menu
/ : Search site
f or F : Jump to
y or Y : Canonical URL