jobmanagement_v1

package
v2.43.0 Latest Latest
Warning

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

Go to latest
Published: Nov 12, 2022 License: Apache-2.0, BSD-3-Clause, MIT Imports: 11 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

View Source
var (
	CommitManifestResponse_Constants_name = map[int32]string{
		0: "NO_ARTIFACTS_STAGED_TOKEN",
	}
	CommitManifestResponse_Constants_value = map[string]int32{
		"NO_ARTIFACTS_STAGED_TOKEN": 0,
	}
)

Enum value maps for CommitManifestResponse_Constants.

View Source
var (
	JobMessage_MessageImportance_name = map[int32]string{
		0: "MESSAGE_IMPORTANCE_UNSPECIFIED",
		1: "JOB_MESSAGE_DEBUG",
		2: "JOB_MESSAGE_DETAILED",
		3: "JOB_MESSAGE_BASIC",
		4: "JOB_MESSAGE_WARNING",
		5: "JOB_MESSAGE_ERROR",
	}
	JobMessage_MessageImportance_value = map[string]int32{
		"MESSAGE_IMPORTANCE_UNSPECIFIED": 0,
		"JOB_MESSAGE_DEBUG":              1,
		"JOB_MESSAGE_DETAILED":           2,
		"JOB_MESSAGE_BASIC":              3,
		"JOB_MESSAGE_WARNING":            4,
		"JOB_MESSAGE_ERROR":              5,
	}
)

Enum value maps for JobMessage_MessageImportance.

View Source
var (
	JobState_Enum_name = map[int32]string{
		0:  "UNSPECIFIED",
		1:  "STOPPED",
		2:  "RUNNING",
		3:  "DONE",
		4:  "FAILED",
		5:  "CANCELLED",
		6:  "UPDATED",
		7:  "DRAINING",
		8:  "DRAINED",
		9:  "STARTING",
		10: "CANCELLING",
		11: "UPDATING",
	}
	JobState_Enum_value = map[string]int32{
		"UNSPECIFIED": 0,
		"STOPPED":     1,
		"RUNNING":     2,
		"DONE":        3,
		"FAILED":      4,
		"CANCELLED":   5,
		"UPDATED":     6,
		"DRAINING":    7,
		"DRAINED":     8,
		"STARTING":    9,
		"CANCELLING":  10,
		"UPDATING":    11,
	}
)

Enum value maps for JobState_Enum.

View Source
var (
	PipelineOptionType_Enum_name = map[int32]string{
		0: "STRING",
		1: "BOOLEAN",
		2: "INTEGER",
		3: "NUMBER",
		4: "ARRAY",
		5: "OBJECT",
	}
	PipelineOptionType_Enum_value = map[string]int32{
		"STRING":  0,
		"BOOLEAN": 1,
		"INTEGER": 2,
		"NUMBER":  3,
		"ARRAY":   4,
		"OBJECT":  5,
	}
)

Enum value maps for PipelineOptionType_Enum.

View Source
var ArtifactRetrievalService_ServiceDesc = grpc.ServiceDesc{
	ServiceName: "org.apache.beam.model.job_management.v1.ArtifactRetrievalService",
	HandlerType: (*ArtifactRetrievalServiceServer)(nil),
	Methods: []grpc.MethodDesc{
		{
			MethodName: "ResolveArtifacts",
			Handler:    _ArtifactRetrievalService_ResolveArtifacts_Handler,
		},
	},
	Streams: []grpc.StreamDesc{
		{
			StreamName:    "GetArtifact",
			Handler:       _ArtifactRetrievalService_GetArtifact_Handler,
			ServerStreams: true,
		},
	},
	Metadata: "org/apache/beam/model/job_management/v1/beam_artifact_api.proto",
}

ArtifactRetrievalService_ServiceDesc is the grpc.ServiceDesc for ArtifactRetrievalService service. It's only intended for direct use with grpc.RegisterService, and not to be introspected or modified (even as a copy)

View Source
var ArtifactStagingService_ServiceDesc = grpc.ServiceDesc{
	ServiceName: "org.apache.beam.model.job_management.v1.ArtifactStagingService",
	HandlerType: (*ArtifactStagingServiceServer)(nil),
	Methods:     []grpc.MethodDesc{},
	Streams: []grpc.StreamDesc{
		{
			StreamName:    "ReverseArtifactRetrievalService",
			Handler:       _ArtifactStagingService_ReverseArtifactRetrievalService_Handler,
			ServerStreams: true,
			ClientStreams: true,
		},
	},
	Metadata: "org/apache/beam/model/job_management/v1/beam_artifact_api.proto",
}

ArtifactStagingService_ServiceDesc is the grpc.ServiceDesc for ArtifactStagingService service. It's only intended for direct use with grpc.RegisterService, and not to be introspected or modified (even as a copy)

View Source
var ExpansionService_ServiceDesc = grpc.ServiceDesc{
	ServiceName: "org.apache.beam.model.expansion.v1.ExpansionService",
	HandlerType: (*ExpansionServiceServer)(nil),
	Methods: []grpc.MethodDesc{
		{
			MethodName: "Expand",
			Handler:    _ExpansionService_Expand_Handler,
		},
	},
	Streams:  []grpc.StreamDesc{},
	Metadata: "org/apache/beam/model/job_management/v1/beam_expansion_api.proto",
}

ExpansionService_ServiceDesc is the grpc.ServiceDesc for ExpansionService service. It's only intended for direct use with grpc.RegisterService, and not to be introspected or modified (even as a copy)

View Source
var File_org_apache_beam_model_job_management_v1_beam_artifact_api_proto protoreflect.FileDescriptor
View Source
var File_org_apache_beam_model_job_management_v1_beam_expansion_api_proto protoreflect.FileDescriptor
View Source
var File_org_apache_beam_model_job_management_v1_beam_job_api_proto protoreflect.FileDescriptor
View Source
var JobService_ServiceDesc = grpc.ServiceDesc{
	ServiceName: "org.apache.beam.model.job_management.v1.JobService",
	HandlerType: (*JobServiceServer)(nil),
	Methods: []grpc.MethodDesc{
		{
			MethodName: "Prepare",
			Handler:    _JobService_Prepare_Handler,
		},
		{
			MethodName: "Run",
			Handler:    _JobService_Run_Handler,
		},
		{
			MethodName: "GetJobs",
			Handler:    _JobService_GetJobs_Handler,
		},
		{
			MethodName: "GetState",
			Handler:    _JobService_GetState_Handler,
		},
		{
			MethodName: "GetPipeline",
			Handler:    _JobService_GetPipeline_Handler,
		},
		{
			MethodName: "Cancel",
			Handler:    _JobService_Cancel_Handler,
		},
		{
			MethodName: "GetJobMetrics",
			Handler:    _JobService_GetJobMetrics_Handler,
		},
		{
			MethodName: "DescribePipelineOptions",
			Handler:    _JobService_DescribePipelineOptions_Handler,
		},
	},
	Streams: []grpc.StreamDesc{
		{
			StreamName:    "GetStateStream",
			Handler:       _JobService_GetStateStream_Handler,
			ServerStreams: true,
		},
		{
			StreamName:    "GetMessageStream",
			Handler:       _JobService_GetMessageStream_Handler,
			ServerStreams: true,
		},
	},
	Metadata: "org/apache/beam/model/job_management/v1/beam_job_api.proto",
}

JobService_ServiceDesc is the grpc.ServiceDesc for JobService service. It's only intended for direct use with grpc.RegisterService, and not to be introspected or modified (even as a copy)

View Source
var LegacyArtifactRetrievalService_ServiceDesc = grpc.ServiceDesc{
	ServiceName: "org.apache.beam.model.job_management.v1.LegacyArtifactRetrievalService",
	HandlerType: (*LegacyArtifactRetrievalServiceServer)(nil),
	Methods: []grpc.MethodDesc{
		{
			MethodName: "GetManifest",
			Handler:    _LegacyArtifactRetrievalService_GetManifest_Handler,
		},
	},
	Streams: []grpc.StreamDesc{
		{
			StreamName:    "GetArtifact",
			Handler:       _LegacyArtifactRetrievalService_GetArtifact_Handler,
			ServerStreams: true,
		},
	},
	Metadata: "org/apache/beam/model/job_management/v1/beam_artifact_api.proto",
}

LegacyArtifactRetrievalService_ServiceDesc is the grpc.ServiceDesc for LegacyArtifactRetrievalService service. It's only intended for direct use with grpc.RegisterService, and not to be introspected or modified (even as a copy)

View Source
var LegacyArtifactStagingService_ServiceDesc = grpc.ServiceDesc{
	ServiceName: "org.apache.beam.model.job_management.v1.LegacyArtifactStagingService",
	HandlerType: (*LegacyArtifactStagingServiceServer)(nil),
	Methods: []grpc.MethodDesc{
		{
			MethodName: "CommitManifest",
			Handler:    _LegacyArtifactStagingService_CommitManifest_Handler,
		},
	},
	Streams: []grpc.StreamDesc{
		{
			StreamName:    "PutArtifact",
			Handler:       _LegacyArtifactStagingService_PutArtifact_Handler,
			ClientStreams: true,
		},
	},
	Metadata: "org/apache/beam/model/job_management/v1/beam_artifact_api.proto",
}

LegacyArtifactStagingService_ServiceDesc is the grpc.ServiceDesc for LegacyArtifactStagingService service. It's only intended for direct use with grpc.RegisterService, and not to be introspected or modified (even as a copy)

Functions

func RegisterArtifactRetrievalServiceServer

func RegisterArtifactRetrievalServiceServer(s grpc.ServiceRegistrar, srv ArtifactRetrievalServiceServer)

func RegisterArtifactStagingServiceServer

func RegisterArtifactStagingServiceServer(s grpc.ServiceRegistrar, srv ArtifactStagingServiceServer)

func RegisterExpansionServiceServer

func RegisterExpansionServiceServer(s grpc.ServiceRegistrar, srv ExpansionServiceServer)

func RegisterJobServiceServer

func RegisterJobServiceServer(s grpc.ServiceRegistrar, srv JobServiceServer)

func RegisterLegacyArtifactRetrievalServiceServer

func RegisterLegacyArtifactRetrievalServiceServer(s grpc.ServiceRegistrar, srv LegacyArtifactRetrievalServiceServer)

func RegisterLegacyArtifactStagingServiceServer

func RegisterLegacyArtifactStagingServiceServer(s grpc.ServiceRegistrar, srv LegacyArtifactStagingServiceServer)

Types

type ArtifactChunk

type ArtifactChunk struct {
	Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"`
	// contains filtered or unexported fields
}

Part of an artifact.

func (*ArtifactChunk) Descriptor deprecated

func (*ArtifactChunk) Descriptor() ([]byte, []int)

Deprecated: Use ArtifactChunk.ProtoReflect.Descriptor instead.

func (*ArtifactChunk) GetData

func (x *ArtifactChunk) GetData() []byte

func (*ArtifactChunk) ProtoMessage

func (*ArtifactChunk) ProtoMessage()

func (*ArtifactChunk) ProtoReflect

func (x *ArtifactChunk) ProtoReflect() protoreflect.Message

func (*ArtifactChunk) Reset

func (x *ArtifactChunk) Reset()

func (*ArtifactChunk) String

func (x *ArtifactChunk) String() string

type ArtifactMetadata

type ArtifactMetadata struct {

	// (Required) The name of the artifact.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// (Optional) The Unix-like permissions of the artifact
	Permissions uint32 `protobuf:"varint,2,opt,name=permissions,proto3" json:"permissions,omitempty"`
	// (Optional) The hex-encoded sha256 checksum of the artifact. Used, among other things, by
	// harness boot code to validate the integrity of the artifact.
	Sha256 string `protobuf:"bytes,4,opt,name=sha256,proto3" json:"sha256,omitempty"`
	// contains filtered or unexported fields
}

An artifact identifier and associated metadata.

func (*ArtifactMetadata) Descriptor deprecated

func (*ArtifactMetadata) Descriptor() ([]byte, []int)

Deprecated: Use ArtifactMetadata.ProtoReflect.Descriptor instead.

func (*ArtifactMetadata) GetName

func (x *ArtifactMetadata) GetName() string

func (*ArtifactMetadata) GetPermissions

func (x *ArtifactMetadata) GetPermissions() uint32

func (*ArtifactMetadata) GetSha256

func (x *ArtifactMetadata) GetSha256() string

func (*ArtifactMetadata) ProtoMessage

func (*ArtifactMetadata) ProtoMessage()

func (*ArtifactMetadata) ProtoReflect

func (x *ArtifactMetadata) ProtoReflect() protoreflect.Message

func (*ArtifactMetadata) Reset

func (x *ArtifactMetadata) Reset()

func (*ArtifactMetadata) String

func (x *ArtifactMetadata) String() string

type ArtifactRequestWrapper

type ArtifactRequestWrapper struct {

	// Types that are assignable to Request:
	//	*ArtifactRequestWrapper_ResolveArtifact
	//	*ArtifactRequestWrapper_GetArtifact
	Request isArtifactRequestWrapper_Request `protobuf_oneof:"request"`
	// contains filtered or unexported fields
}

Wraps an ArtifactRetrievalService request for use in ReverseArtifactRetrievalService.

func (*ArtifactRequestWrapper) Descriptor deprecated

func (*ArtifactRequestWrapper) Descriptor() ([]byte, []int)

Deprecated: Use ArtifactRequestWrapper.ProtoReflect.Descriptor instead.

func (*ArtifactRequestWrapper) GetGetArtifact

func (x *ArtifactRequestWrapper) GetGetArtifact() *GetArtifactRequest

func (*ArtifactRequestWrapper) GetRequest

func (m *ArtifactRequestWrapper) GetRequest() isArtifactRequestWrapper_Request

func (*ArtifactRequestWrapper) GetResolveArtifact

func (x *ArtifactRequestWrapper) GetResolveArtifact() *ResolveArtifactsRequest

func (*ArtifactRequestWrapper) ProtoMessage

func (*ArtifactRequestWrapper) ProtoMessage()

func (*ArtifactRequestWrapper) ProtoReflect

func (x *ArtifactRequestWrapper) ProtoReflect() protoreflect.Message

func (*ArtifactRequestWrapper) Reset

func (x *ArtifactRequestWrapper) Reset()

func (*ArtifactRequestWrapper) String

func (x *ArtifactRequestWrapper) String() string

type ArtifactRequestWrapper_GetArtifact

type ArtifactRequestWrapper_GetArtifact struct {
	GetArtifact *GetArtifactRequest `protobuf:"bytes,1001,opt,name=get_artifact,json=getArtifact,proto3,oneof"`
}

type ArtifactRequestWrapper_ResolveArtifact

type ArtifactRequestWrapper_ResolveArtifact struct {
	ResolveArtifact *ResolveArtifactsRequest `protobuf:"bytes,1000,opt,name=resolve_artifact,json=resolveArtifact,proto3,oneof"`
}

type ArtifactResponseWrapper

type ArtifactResponseWrapper struct {

	// A token indicating which job these artifacts are being staged for.
	StagingToken string `protobuf:"bytes,1,opt,name=staging_token,json=stagingToken,proto3" json:"staging_token,omitempty"`
	// Whether this is the last response for this request (for those responses that
	// would typically be terminated by the end of the response stream.)
	IsLast bool `protobuf:"varint,2,opt,name=is_last,json=isLast,proto3" json:"is_last,omitempty"`
	// The response itself.
	//
	// Types that are assignable to Response:
	//	*ArtifactResponseWrapper_ResolveArtifactResponse
	//	*ArtifactResponseWrapper_GetArtifactResponse
	Response isArtifactResponseWrapper_Response `protobuf_oneof:"response"`
	// contains filtered or unexported fields
}

Wraps an ArtifactRetrievalService response for use in ReverseArtifactRetrievalService.

func (*ArtifactResponseWrapper) Descriptor deprecated

func (*ArtifactResponseWrapper) Descriptor() ([]byte, []int)

Deprecated: Use ArtifactResponseWrapper.ProtoReflect.Descriptor instead.

func (*ArtifactResponseWrapper) GetGetArtifactResponse

func (x *ArtifactResponseWrapper) GetGetArtifactResponse() *GetArtifactResponse

func (*ArtifactResponseWrapper) GetIsLast

func (x *ArtifactResponseWrapper) GetIsLast() bool

func (*ArtifactResponseWrapper) GetResolveArtifactResponse

func (x *ArtifactResponseWrapper) GetResolveArtifactResponse() *ResolveArtifactsResponse

func (*ArtifactResponseWrapper) GetResponse

func (m *ArtifactResponseWrapper) GetResponse() isArtifactResponseWrapper_Response

func (*ArtifactResponseWrapper) GetStagingToken

func (x *ArtifactResponseWrapper) GetStagingToken() string

func (*ArtifactResponseWrapper) ProtoMessage

func (*ArtifactResponseWrapper) ProtoMessage()

func (*ArtifactResponseWrapper) ProtoReflect

func (x *ArtifactResponseWrapper) ProtoReflect() protoreflect.Message

func (*ArtifactResponseWrapper) Reset

func (x *ArtifactResponseWrapper) Reset()

func (*ArtifactResponseWrapper) String

func (x *ArtifactResponseWrapper) String() string

type ArtifactResponseWrapper_GetArtifactResponse

type ArtifactResponseWrapper_GetArtifactResponse struct {
	GetArtifactResponse *GetArtifactResponse `protobuf:"bytes,1001,opt,name=get_artifact_response,json=getArtifactResponse,proto3,oneof"`
}

type ArtifactResponseWrapper_ResolveArtifactResponse

type ArtifactResponseWrapper_ResolveArtifactResponse struct {
	ResolveArtifactResponse *ResolveArtifactsResponse `protobuf:"bytes,1000,opt,name=resolve_artifact_response,json=resolveArtifactResponse,proto3,oneof"`
}

type ArtifactRetrievalServiceClient

type ArtifactRetrievalServiceClient interface {
	// Resolves the given artifact references into one or more replacement
	// artifact references (e.g. a Maven dependency into a (transitive) set
	// of jars.
	ResolveArtifacts(ctx context.Context, in *ResolveArtifactsRequest, opts ...grpc.CallOption) (*ResolveArtifactsResponse, error)
	// Retrieves the given artifact as a stream of bytes.
	GetArtifact(ctx context.Context, in *GetArtifactRequest, opts ...grpc.CallOption) (ArtifactRetrievalService_GetArtifactClient, error)
}

ArtifactRetrievalServiceClient is the client API for ArtifactRetrievalService service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream.

type ArtifactRetrievalServiceServer

type ArtifactRetrievalServiceServer interface {
	// Resolves the given artifact references into one or more replacement
	// artifact references (e.g. a Maven dependency into a (transitive) set
	// of jars.
	ResolveArtifacts(context.Context, *ResolveArtifactsRequest) (*ResolveArtifactsResponse, error)
	// Retrieves the given artifact as a stream of bytes.
	GetArtifact(*GetArtifactRequest, ArtifactRetrievalService_GetArtifactServer) error
	// contains filtered or unexported methods
}

ArtifactRetrievalServiceServer is the server API for ArtifactRetrievalService service. All implementations must embed UnimplementedArtifactRetrievalServiceServer for forward compatibility

type ArtifactRetrievalService_GetArtifactClient

type ArtifactRetrievalService_GetArtifactClient interface {
	Recv() (*GetArtifactResponse, error)
	grpc.ClientStream
}

type ArtifactRetrievalService_GetArtifactServer

type ArtifactRetrievalService_GetArtifactServer interface {
	Send(*GetArtifactResponse) error
	grpc.ServerStream
}

type ArtifactStagingServiceClient

type ArtifactStagingServiceClient interface {
	ReverseArtifactRetrievalService(ctx context.Context, opts ...grpc.CallOption) (ArtifactStagingService_ReverseArtifactRetrievalServiceClient, error)
}

ArtifactStagingServiceClient is the client API for ArtifactStagingService service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream.

type ArtifactStagingServiceServer

type ArtifactStagingServiceServer interface {
	ReverseArtifactRetrievalService(ArtifactStagingService_ReverseArtifactRetrievalServiceServer) error
	// contains filtered or unexported methods
}

ArtifactStagingServiceServer is the server API for ArtifactStagingService service. All implementations must embed UnimplementedArtifactStagingServiceServer for forward compatibility

type ArtifactStagingService_ReverseArtifactRetrievalServiceClient

type ArtifactStagingService_ReverseArtifactRetrievalServiceClient interface {
	Send(*ArtifactResponseWrapper) error
	Recv() (*ArtifactRequestWrapper, error)
	grpc.ClientStream
}

type ArtifactStagingService_ReverseArtifactRetrievalServiceServer

type ArtifactStagingService_ReverseArtifactRetrievalServiceServer interface {
	Send(*ArtifactRequestWrapper) error
	Recv() (*ArtifactResponseWrapper, error)
	grpc.ServerStream
}

type CancelJobRequest

type CancelJobRequest struct {
	JobId string `protobuf:"bytes,1,opt,name=job_id,json=jobId,proto3" json:"job_id,omitempty"` // (required)
	// contains filtered or unexported fields
}

Cancel is a synchronus request that returns a job state back Throws error GRPC_STATUS_UNAVAILABLE if server is down Throws error NOT_FOUND if the jobId is not found

func (*CancelJobRequest) Descriptor deprecated

func (*CancelJobRequest) Descriptor() ([]byte, []int)

Deprecated: Use CancelJobRequest.ProtoReflect.Descriptor instead.

func (*CancelJobRequest) GetJobId

func (x *CancelJobRequest) GetJobId() string

func (*CancelJobRequest) ProtoMessage

func (*CancelJobRequest) ProtoMessage()

func (*CancelJobRequest) ProtoReflect

func (x *CancelJobRequest) ProtoReflect() protoreflect.Message

func (*CancelJobRequest) Reset

func (x *CancelJobRequest) Reset()

func (*CancelJobRequest) String

func (x *CancelJobRequest) String() string

type CancelJobResponse

type CancelJobResponse struct {
	State JobState_Enum `protobuf:"varint,1,opt,name=state,proto3,enum=org.apache.beam.model.job_management.v1.JobState_Enum" json:"state,omitempty"` // (required)
	// contains filtered or unexported fields
}

Valid responses include any terminal state or CANCELLING

func (*CancelJobResponse) Descriptor deprecated

func (*CancelJobResponse) Descriptor() ([]byte, []int)

Deprecated: Use CancelJobResponse.ProtoReflect.Descriptor instead.

func (*CancelJobResponse) GetState

func (x *CancelJobResponse) GetState() JobState_Enum

func (*CancelJobResponse) ProtoMessage

func (*CancelJobResponse) ProtoMessage()

func (*CancelJobResponse) ProtoReflect

func (x *CancelJobResponse) ProtoReflect() protoreflect.Message

func (*CancelJobResponse) Reset

func (x *CancelJobResponse) Reset()

func (*CancelJobResponse) String

func (x *CancelJobResponse) String() string

type CommitManifestRequest

type CommitManifestRequest struct {

	// (Required) The manifest to commit.
	Manifest *Manifest `protobuf:"bytes,1,opt,name=manifest,proto3" json:"manifest,omitempty"`
	// (Required) A token for artifact staging session. This token can be obtained
	// from PrepareJob request in JobService
	StagingSessionToken string `protobuf:"bytes,2,opt,name=staging_session_token,json=stagingSessionToken,proto3" json:"staging_session_token,omitempty"`
	// contains filtered or unexported fields
}

A request to commit the manifest for a Job. All artifacts must have been successfully uploaded before this call is made.

func (*CommitManifestRequest) Descriptor deprecated

func (*CommitManifestRequest) Descriptor() ([]byte, []int)

Deprecated: Use CommitManifestRequest.ProtoReflect.Descriptor instead.

func (*CommitManifestRequest) GetManifest

func (x *CommitManifestRequest) GetManifest() *Manifest

func (*CommitManifestRequest) GetStagingSessionToken

func (x *CommitManifestRequest) GetStagingSessionToken() string

func (*CommitManifestRequest) ProtoMessage

func (*CommitManifestRequest) ProtoMessage()

func (*CommitManifestRequest) ProtoReflect

func (x *CommitManifestRequest) ProtoReflect() protoreflect.Message

func (*CommitManifestRequest) Reset

func (x *CommitManifestRequest) Reset()

func (*CommitManifestRequest) String

func (x *CommitManifestRequest) String() string

type CommitManifestResponse

type CommitManifestResponse struct {

	// (Required) An opaque token representing the entirety of the staged artifacts.
	// This can be used to retrieve the manifest and artifacts from an associated
	// LegacyArtifactRetrievalService.
	RetrievalToken string `protobuf:"bytes,1,opt,name=retrieval_token,json=retrievalToken,proto3" json:"retrieval_token,omitempty"`
	// contains filtered or unexported fields
}

The result of committing a manifest.

func (*CommitManifestResponse) Descriptor deprecated

func (*CommitManifestResponse) Descriptor() ([]byte, []int)

Deprecated: Use CommitManifestResponse.ProtoReflect.Descriptor instead.

func (*CommitManifestResponse) GetRetrievalToken

func (x *CommitManifestResponse) GetRetrievalToken() string

func (*CommitManifestResponse) ProtoMessage

func (*CommitManifestResponse) ProtoMessage()

func (*CommitManifestResponse) ProtoReflect

func (x *CommitManifestResponse) ProtoReflect() protoreflect.Message

func (*CommitManifestResponse) Reset

func (x *CommitManifestResponse) Reset()

func (*CommitManifestResponse) String

func (x *CommitManifestResponse) String() string

type CommitManifestResponse_Constants

type CommitManifestResponse_Constants int32
const (
	// Token indicating that no artifacts were staged and therefore no retrieval attempt is necessary.
	CommitManifestResponse_NO_ARTIFACTS_STAGED_TOKEN CommitManifestResponse_Constants = 0
)

func (CommitManifestResponse_Constants) Descriptor

func (CommitManifestResponse_Constants) Enum

func (CommitManifestResponse_Constants) EnumDescriptor deprecated

func (CommitManifestResponse_Constants) EnumDescriptor() ([]byte, []int)

Deprecated: Use CommitManifestResponse_Constants.Descriptor instead.

func (CommitManifestResponse_Constants) Number

func (CommitManifestResponse_Constants) String

func (CommitManifestResponse_Constants) Type

type DescribePipelineOptionsRequest

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

DescribePipelineOptions provides metadata about the options supported by a runner. It will be used by the SDK client to validate the options specified by or list available options to the user. Throws error GRPC_STATUS_UNAVAILABLE if server is down

func (*DescribePipelineOptionsRequest) Descriptor deprecated

func (*DescribePipelineOptionsRequest) Descriptor() ([]byte, []int)

Deprecated: Use DescribePipelineOptionsRequest.ProtoReflect.Descriptor instead.

func (*DescribePipelineOptionsRequest) ProtoMessage

func (*DescribePipelineOptionsRequest) ProtoMessage()

func (*DescribePipelineOptionsRequest) ProtoReflect

func (*DescribePipelineOptionsRequest) Reset

func (x *DescribePipelineOptionsRequest) Reset()

func (*DescribePipelineOptionsRequest) String

type DescribePipelineOptionsResponse

type DescribePipelineOptionsResponse struct {

	// List of pipeline option descriptors.
	Options []*PipelineOptionDescriptor `protobuf:"bytes,1,rep,name=options,proto3" json:"options,omitempty"`
	// contains filtered or unexported fields
}

func (*DescribePipelineOptionsResponse) Descriptor deprecated

func (*DescribePipelineOptionsResponse) Descriptor() ([]byte, []int)

Deprecated: Use DescribePipelineOptionsResponse.ProtoReflect.Descriptor instead.

func (*DescribePipelineOptionsResponse) GetOptions

func (*DescribePipelineOptionsResponse) ProtoMessage

func (*DescribePipelineOptionsResponse) ProtoMessage()

func (*DescribePipelineOptionsResponse) ProtoReflect

func (*DescribePipelineOptionsResponse) Reset

func (*DescribePipelineOptionsResponse) String

type ExpansionRequest

type ExpansionRequest struct {

	// Set of components needed to interpret the transform, or which
	// may be useful for its expansion.  This includes the input
	// PCollections (if any) to the to-be-expanded transform, along
	// with their coders and windowing strategies.
	Components *pipeline_v1.Components `protobuf:"bytes,1,opt,name=components,proto3" json:"components,omitempty"`
	// The actual PTransform to be expaneded according to its spec.
	// Its input should be set, but its subtransforms and outputs
	// should not be.
	Transform *pipeline_v1.PTransform `protobuf:"bytes,2,opt,name=transform,proto3" json:"transform,omitempty"`
	// A namespace (prefix) to use for the id of any newly created
	// components.
	Namespace string `protobuf:"bytes,3,opt,name=namespace,proto3" json:"namespace,omitempty"`
	// (Optional) Map from a local output tag to a coder id.
	// If it is set, asks the expansion service to use the given
	// coders for the output PCollections. Note that the request
	// may not be fulfilled.
	OutputCoderRequests map[string]string `` /* 208-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*ExpansionRequest) Descriptor deprecated

func (*ExpansionRequest) Descriptor() ([]byte, []int)

Deprecated: Use ExpansionRequest.ProtoReflect.Descriptor instead.

func (*ExpansionRequest) GetComponents

func (x *ExpansionRequest) GetComponents() *pipeline_v1.Components

func (*ExpansionRequest) GetNamespace

func (x *ExpansionRequest) GetNamespace() string

func (*ExpansionRequest) GetOutputCoderRequests added in v2.43.0

func (x *ExpansionRequest) GetOutputCoderRequests() map[string]string

func (*ExpansionRequest) GetTransform

func (x *ExpansionRequest) GetTransform() *pipeline_v1.PTransform

func (*ExpansionRequest) ProtoMessage

func (*ExpansionRequest) ProtoMessage()

func (*ExpansionRequest) ProtoReflect

func (x *ExpansionRequest) ProtoReflect() protoreflect.Message

func (*ExpansionRequest) Reset

func (x *ExpansionRequest) Reset()

func (*ExpansionRequest) String

func (x *ExpansionRequest) String() string

type ExpansionResponse

type ExpansionResponse struct {

	// Set of components needed to execute the expanded transform,
	// including the (original) inputs, outputs, and subtransforms.
	Components *pipeline_v1.Components `protobuf:"bytes,1,opt,name=components,proto3" json:"components,omitempty"`
	// The expanded transform itself, with references to its outputs
	// and subtransforms.
	Transform *pipeline_v1.PTransform `protobuf:"bytes,2,opt,name=transform,proto3" json:"transform,omitempty"`
	// A set of requirements that must be appended to this pipeline's
	// requirements.
	Requirements []string `protobuf:"bytes,3,rep,name=requirements,proto3" json:"requirements,omitempty"`
	// (Optional) An string representation of any error encountered while
	// attempting to expand this transform.
	Error string `protobuf:"bytes,10,opt,name=error,proto3" json:"error,omitempty"`
	// contains filtered or unexported fields
}

func (*ExpansionResponse) Descriptor deprecated

func (*ExpansionResponse) Descriptor() ([]byte, []int)

Deprecated: Use ExpansionResponse.ProtoReflect.Descriptor instead.

func (*ExpansionResponse) GetComponents

func (x *ExpansionResponse) GetComponents() *pipeline_v1.Components

func (*ExpansionResponse) GetError

func (x *ExpansionResponse) GetError() string

func (*ExpansionResponse) GetRequirements

func (x *ExpansionResponse) GetRequirements() []string

func (*ExpansionResponse) GetTransform

func (x *ExpansionResponse) GetTransform() *pipeline_v1.PTransform

func (*ExpansionResponse) ProtoMessage

func (*ExpansionResponse) ProtoMessage()

func (*ExpansionResponse) ProtoReflect

func (x *ExpansionResponse) ProtoReflect() protoreflect.Message

func (*ExpansionResponse) Reset

func (x *ExpansionResponse) Reset()

func (*ExpansionResponse) String

func (x *ExpansionResponse) String() string

type ExpansionServiceClient

type ExpansionServiceClient interface {
	Expand(ctx context.Context, in *ExpansionRequest, opts ...grpc.CallOption) (*ExpansionResponse, error)
}

ExpansionServiceClient is the client API for ExpansionService service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream.

type ExpansionServiceServer

type ExpansionServiceServer interface {
	Expand(context.Context, *ExpansionRequest) (*ExpansionResponse, error)
	// contains filtered or unexported methods
}

ExpansionServiceServer is the server API for ExpansionService service. All implementations must embed UnimplementedExpansionServiceServer for forward compatibility

type GetArtifactRequest

type GetArtifactRequest struct {
	Artifact *pipeline_v1.ArtifactInformation `protobuf:"bytes,1,opt,name=artifact,proto3" json:"artifact,omitempty"`
	// contains filtered or unexported fields
}

A request to get an artifact.

func (*GetArtifactRequest) Descriptor deprecated

func (*GetArtifactRequest) Descriptor() ([]byte, []int)

Deprecated: Use GetArtifactRequest.ProtoReflect.Descriptor instead.

func (*GetArtifactRequest) GetArtifact

func (*GetArtifactRequest) ProtoMessage

func (*GetArtifactRequest) ProtoMessage()

func (*GetArtifactRequest) ProtoReflect

func (x *GetArtifactRequest) ProtoReflect() protoreflect.Message

func (*GetArtifactRequest) Reset

func (x *GetArtifactRequest) Reset()

func (*GetArtifactRequest) String

func (x *GetArtifactRequest) String() string

type GetArtifactResponse

type GetArtifactResponse struct {
	Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"`
	// contains filtered or unexported fields
}

Part of a response to getting an artifact.

func (*GetArtifactResponse) Descriptor deprecated

func (*GetArtifactResponse) Descriptor() ([]byte, []int)

Deprecated: Use GetArtifactResponse.ProtoReflect.Descriptor instead.

func (*GetArtifactResponse) GetData

func (x *GetArtifactResponse) GetData() []byte

func (*GetArtifactResponse) ProtoMessage

func (*GetArtifactResponse) ProtoMessage()

func (*GetArtifactResponse) ProtoReflect

func (x *GetArtifactResponse) ProtoReflect() protoreflect.Message

func (*GetArtifactResponse) Reset

func (x *GetArtifactResponse) Reset()

func (*GetArtifactResponse) String

func (x *GetArtifactResponse) String() string

type GetJobMetricsRequest

type GetJobMetricsRequest struct {
	JobId string `protobuf:"bytes,1,opt,name=job_id,json=jobId,proto3" json:"job_id,omitempty"` // (required)
	// contains filtered or unexported fields
}

func (*GetJobMetricsRequest) Descriptor deprecated

func (*GetJobMetricsRequest) Descriptor() ([]byte, []int)

Deprecated: Use GetJobMetricsRequest.ProtoReflect.Descriptor instead.

func (*GetJobMetricsRequest) GetJobId

func (x *GetJobMetricsRequest) GetJobId() string

func (*GetJobMetricsRequest) ProtoMessage

func (*GetJobMetricsRequest) ProtoMessage()

func (*GetJobMetricsRequest) ProtoReflect

func (x *GetJobMetricsRequest) ProtoReflect() protoreflect.Message

func (*GetJobMetricsRequest) Reset

func (x *GetJobMetricsRequest) Reset()

func (*GetJobMetricsRequest) String

func (x *GetJobMetricsRequest) String() string

type GetJobMetricsResponse

type GetJobMetricsResponse struct {
	Metrics *MetricResults `protobuf:"bytes,1,opt,name=metrics,proto3" json:"metrics,omitempty"`
	// contains filtered or unexported fields
}

func (*GetJobMetricsResponse) Descriptor deprecated

func (*GetJobMetricsResponse) Descriptor() ([]byte, []int)

Deprecated: Use GetJobMetricsResponse.ProtoReflect.Descriptor instead.

func (*GetJobMetricsResponse) GetMetrics

func (x *GetJobMetricsResponse) GetMetrics() *MetricResults

func (*GetJobMetricsResponse) ProtoMessage

func (*GetJobMetricsResponse) ProtoMessage()

func (*GetJobMetricsResponse) ProtoReflect

func (x *GetJobMetricsResponse) ProtoReflect() protoreflect.Message

func (*GetJobMetricsResponse) Reset

func (x *GetJobMetricsResponse) Reset()

func (*GetJobMetricsResponse) String

func (x *GetJobMetricsResponse) String() string

type GetJobPipelineRequest

type GetJobPipelineRequest struct {
	JobId string `protobuf:"bytes,1,opt,name=job_id,json=jobId,proto3" json:"job_id,omitempty"` // (required)
	// contains filtered or unexported fields
}

GetPipeline is a synchronus request that returns a pipeline back Throws error GRPC_STATUS_UNAVAILABLE if server is down Throws error NOT_FOUND if the jobId is not found

func (*GetJobPipelineRequest) Descriptor deprecated

func (*GetJobPipelineRequest) Descriptor() ([]byte, []int)

Deprecated: Use GetJobPipelineRequest.ProtoReflect.Descriptor instead.

func (*GetJobPipelineRequest) GetJobId

func (x *GetJobPipelineRequest) GetJobId() string

func (*GetJobPipelineRequest) ProtoMessage

func (*GetJobPipelineRequest) ProtoMessage()

func (*GetJobPipelineRequest) ProtoReflect

func (x *GetJobPipelineRequest) ProtoReflect() protoreflect.Message

func (*GetJobPipelineRequest) Reset

func (x *GetJobPipelineRequest) Reset()

func (*GetJobPipelineRequest) String

func (x *GetJobPipelineRequest) String() string

type GetJobPipelineResponse

type GetJobPipelineResponse struct {
	Pipeline *pipeline_v1.Pipeline `protobuf:"bytes,1,opt,name=pipeline,proto3" json:"pipeline,omitempty"` // (required)
	// contains filtered or unexported fields
}

func (*GetJobPipelineResponse) Descriptor deprecated

func (*GetJobPipelineResponse) Descriptor() ([]byte, []int)

Deprecated: Use GetJobPipelineResponse.ProtoReflect.Descriptor instead.

func (*GetJobPipelineResponse) GetPipeline

func (x *GetJobPipelineResponse) GetPipeline() *pipeline_v1.Pipeline

func (*GetJobPipelineResponse) ProtoMessage

func (*GetJobPipelineResponse) ProtoMessage()

func (*GetJobPipelineResponse) ProtoReflect

func (x *GetJobPipelineResponse) ProtoReflect() protoreflect.Message

func (*GetJobPipelineResponse) Reset

func (x *GetJobPipelineResponse) Reset()

func (*GetJobPipelineResponse) String

func (x *GetJobPipelineResponse) String() string

type GetJobStateRequest

type GetJobStateRequest struct {
	JobId string `protobuf:"bytes,1,opt,name=job_id,json=jobId,proto3" json:"job_id,omitempty"` // (required)
	// contains filtered or unexported fields
}

GetState is a synchronus request that returns a job state back Throws error GRPC_STATUS_UNAVAILABLE if server is down Throws error NOT_FOUND if the jobId is not found

func (*GetJobStateRequest) Descriptor deprecated

func (*GetJobStateRequest) Descriptor() ([]byte, []int)

Deprecated: Use GetJobStateRequest.ProtoReflect.Descriptor instead.

func (*GetJobStateRequest) GetJobId

func (x *GetJobStateRequest) GetJobId() string

func (*GetJobStateRequest) ProtoMessage

func (*GetJobStateRequest) ProtoMessage()

func (*GetJobStateRequest) ProtoReflect

func (x *GetJobStateRequest) ProtoReflect() protoreflect.Message

func (*GetJobStateRequest) Reset

func (x *GetJobStateRequest) Reset()

func (*GetJobStateRequest) String

func (x *GetJobStateRequest) String() string

type GetJobsRequest

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

GetJobs is a synchronus request that returns a list of invoked jobs back Throws error GRPC_STATUS_UNAVAILABLE if server is down

func (*GetJobsRequest) Descriptor deprecated

func (*GetJobsRequest) Descriptor() ([]byte, []int)

Deprecated: Use GetJobsRequest.ProtoReflect.Descriptor instead.

func (*GetJobsRequest) ProtoMessage

func (*GetJobsRequest) ProtoMessage()

func (*GetJobsRequest) ProtoReflect

func (x *GetJobsRequest) ProtoReflect() protoreflect.Message

func (*GetJobsRequest) Reset

func (x *GetJobsRequest) Reset()

func (*GetJobsRequest) String

func (x *GetJobsRequest) String() string

type GetJobsResponse

type GetJobsResponse struct {
	JobInfo []*JobInfo `protobuf:"bytes,1,rep,name=job_info,json=jobInfo,proto3" json:"job_info,omitempty"` // (required)
	// contains filtered or unexported fields
}

func (*GetJobsResponse) Descriptor deprecated

func (*GetJobsResponse) Descriptor() ([]byte, []int)

Deprecated: Use GetJobsResponse.ProtoReflect.Descriptor instead.

func (*GetJobsResponse) GetJobInfo

func (x *GetJobsResponse) GetJobInfo() []*JobInfo

func (*GetJobsResponse) ProtoMessage

func (*GetJobsResponse) ProtoMessage()

func (*GetJobsResponse) ProtoReflect

func (x *GetJobsResponse) ProtoReflect() protoreflect.Message

func (*GetJobsResponse) Reset

func (x *GetJobsResponse) Reset()

func (*GetJobsResponse) String

func (x *GetJobsResponse) String() string

type GetManifestRequest

type GetManifestRequest struct {

	// (Required) An opaque token representing the entirety of the staged artifacts.
	// Returned in CommitManifestResponse.
	RetrievalToken string `protobuf:"bytes,1,opt,name=retrieval_token,json=retrievalToken,proto3" json:"retrieval_token,omitempty"`
	// contains filtered or unexported fields
}

A request to get the manifest of a Job.

func (*GetManifestRequest) Descriptor deprecated

func (*GetManifestRequest) Descriptor() ([]byte, []int)

Deprecated: Use GetManifestRequest.ProtoReflect.Descriptor instead.

func (*GetManifestRequest) GetRetrievalToken

func (x *GetManifestRequest) GetRetrievalToken() string

func (*GetManifestRequest) ProtoMessage

func (*GetManifestRequest) ProtoMessage()

func (*GetManifestRequest) ProtoReflect

func (x *GetManifestRequest) ProtoReflect() protoreflect.Message

func (*GetManifestRequest) Reset

func (x *GetManifestRequest) Reset()

func (*GetManifestRequest) String

func (x *GetManifestRequest) String() string

type GetManifestResponse

type GetManifestResponse struct {
	Manifest *Manifest `protobuf:"bytes,1,opt,name=manifest,proto3" json:"manifest,omitempty"`
	// contains filtered or unexported fields
}

A response containing a job manifest.

func (*GetManifestResponse) Descriptor deprecated

func (*GetManifestResponse) Descriptor() ([]byte, []int)

Deprecated: Use GetManifestResponse.ProtoReflect.Descriptor instead.

func (*GetManifestResponse) GetManifest

func (x *GetManifestResponse) GetManifest() *Manifest

func (*GetManifestResponse) ProtoMessage

func (*GetManifestResponse) ProtoMessage()

func (*GetManifestResponse) ProtoReflect

func (x *GetManifestResponse) ProtoReflect() protoreflect.Message

func (*GetManifestResponse) Reset

func (x *GetManifestResponse) Reset()

func (*GetManifestResponse) String

func (x *GetManifestResponse) String() string

type JobInfo

type JobInfo struct {
	JobId           string           `protobuf:"bytes,1,opt,name=job_id,json=jobId,proto3" json:"job_id,omitempty"`                                                // (required)
	JobName         string           `protobuf:"bytes,2,opt,name=job_name,json=jobName,proto3" json:"job_name,omitempty"`                                          // (required)
	PipelineOptions *structpb.Struct `protobuf:"bytes,3,opt,name=pipeline_options,json=pipelineOptions,proto3" json:"pipeline_options,omitempty"`                  // (required)
	State           JobState_Enum    `protobuf:"varint,4,opt,name=state,proto3,enum=org.apache.beam.model.job_management.v1.JobState_Enum" json:"state,omitempty"` // (required)
	// contains filtered or unexported fields
}

A subset of info provided by ProvisionApi.ProvisionInfo

func (*JobInfo) Descriptor deprecated

func (*JobInfo) Descriptor() ([]byte, []int)

Deprecated: Use JobInfo.ProtoReflect.Descriptor instead.

func (*JobInfo) GetJobId

func (x *JobInfo) GetJobId() string

func (*JobInfo) GetJobName

func (x *JobInfo) GetJobName() string

func (*JobInfo) GetPipelineOptions

func (x *JobInfo) GetPipelineOptions() *structpb.Struct

func (*JobInfo) GetState

func (x *JobInfo) GetState() JobState_Enum

func (*JobInfo) ProtoMessage

func (*JobInfo) ProtoMessage()

func (*JobInfo) ProtoReflect

func (x *JobInfo) ProtoReflect() protoreflect.Message

func (*JobInfo) Reset

func (x *JobInfo) Reset()

func (*JobInfo) String

func (x *JobInfo) String() string

type JobMessage

type JobMessage struct {
	MessageId   string                       `protobuf:"bytes,1,opt,name=message_id,json=messageId,proto3" json:"message_id,omitempty"`
	Time        string                       `protobuf:"bytes,2,opt,name=time,proto3" json:"time,omitempty"`
	Importance  JobMessage_MessageImportance `` /* 148-byte string literal not displayed */
	MessageText string                       `protobuf:"bytes,4,opt,name=message_text,json=messageText,proto3" json:"message_text,omitempty"`
	// contains filtered or unexported fields
}

func (*JobMessage) Descriptor deprecated

func (*JobMessage) Descriptor() ([]byte, []int)

Deprecated: Use JobMessage.ProtoReflect.Descriptor instead.

func (*JobMessage) GetImportance

func (x *JobMessage) GetImportance() JobMessage_MessageImportance

func (*JobMessage) GetMessageId

func (x *JobMessage) GetMessageId() string

func (*JobMessage) GetMessageText

func (x *JobMessage) GetMessageText() string

func (*JobMessage) GetTime

func (x *JobMessage) GetTime() string

func (*JobMessage) ProtoMessage

func (*JobMessage) ProtoMessage()

func (*JobMessage) ProtoReflect

func (x *JobMessage) ProtoReflect() protoreflect.Message

func (*JobMessage) Reset

func (x *JobMessage) Reset()

func (*JobMessage) String

func (x *JobMessage) String() string

type JobMessage_MessageImportance

type JobMessage_MessageImportance int32
const (
	JobMessage_MESSAGE_IMPORTANCE_UNSPECIFIED JobMessage_MessageImportance = 0
	JobMessage_JOB_MESSAGE_DEBUG              JobMessage_MessageImportance = 1
	JobMessage_JOB_MESSAGE_DETAILED           JobMessage_MessageImportance = 2
	JobMessage_JOB_MESSAGE_BASIC              JobMessage_MessageImportance = 3
	JobMessage_JOB_MESSAGE_WARNING            JobMessage_MessageImportance = 4
	JobMessage_JOB_MESSAGE_ERROR              JobMessage_MessageImportance = 5
)

func (JobMessage_MessageImportance) Descriptor

func (JobMessage_MessageImportance) Enum

func (JobMessage_MessageImportance) EnumDescriptor deprecated

func (JobMessage_MessageImportance) EnumDescriptor() ([]byte, []int)

Deprecated: Use JobMessage_MessageImportance.Descriptor instead.

func (JobMessage_MessageImportance) Number

func (JobMessage_MessageImportance) String

func (JobMessage_MessageImportance) Type

type JobMessagesRequest

type JobMessagesRequest struct {
	JobId string `protobuf:"bytes,1,opt,name=job_id,json=jobId,proto3" json:"job_id,omitempty"` // (required)
	// contains filtered or unexported fields
}

GetJobMessages is a streaming api for streaming job messages from the service One request will connect you to the job and you'll get a stream of job state and job messages back; one is used for logging and the other for detecting the job ended.

func (*JobMessagesRequest) Descriptor deprecated

func (*JobMessagesRequest) Descriptor() ([]byte, []int)

Deprecated: Use JobMessagesRequest.ProtoReflect.Descriptor instead.

func (*JobMessagesRequest) GetJobId

func (x *JobMessagesRequest) GetJobId() string

func (*JobMessagesRequest) ProtoMessage

func (*JobMessagesRequest) ProtoMessage()

func (*JobMessagesRequest) ProtoReflect

func (x *JobMessagesRequest) ProtoReflect() protoreflect.Message

func (*JobMessagesRequest) Reset

func (x *JobMessagesRequest) Reset()

func (*JobMessagesRequest) String

func (x *JobMessagesRequest) String() string

type JobMessagesResponse

type JobMessagesResponse struct {

	// Types that are assignable to Response:
	//	*JobMessagesResponse_MessageResponse
	//	*JobMessagesResponse_StateResponse
	Response isJobMessagesResponse_Response `protobuf_oneof:"response"`
	// contains filtered or unexported fields
}

func (*JobMessagesResponse) Descriptor deprecated

func (*JobMessagesResponse) Descriptor() ([]byte, []int)

Deprecated: Use JobMessagesResponse.ProtoReflect.Descriptor instead.

func (*JobMessagesResponse) GetMessageResponse

func (x *JobMessagesResponse) GetMessageResponse() *JobMessage

func (*JobMessagesResponse) GetResponse

func (m *JobMessagesResponse) GetResponse() isJobMessagesResponse_Response

func (*JobMessagesResponse) GetStateResponse

func (x *JobMessagesResponse) GetStateResponse() *JobStateEvent

func (*JobMessagesResponse) ProtoMessage

func (*JobMessagesResponse) ProtoMessage()

func (*JobMessagesResponse) ProtoReflect

func (x *JobMessagesResponse) ProtoReflect() protoreflect.Message

func (*JobMessagesResponse) Reset

func (x *JobMessagesResponse) Reset()

func (*JobMessagesResponse) String

func (x *JobMessagesResponse) String() string

type JobMessagesResponse_MessageResponse

type JobMessagesResponse_MessageResponse struct {
	MessageResponse *JobMessage `protobuf:"bytes,1,opt,name=message_response,json=messageResponse,proto3,oneof"`
}

type JobMessagesResponse_StateResponse

type JobMessagesResponse_StateResponse struct {
	StateResponse *JobStateEvent `protobuf:"bytes,2,opt,name=state_response,json=stateResponse,proto3,oneof"`
}

type JobServiceClient

type JobServiceClient interface {
	// Prepare a job for execution. The job will not be executed until a call is made to run with the
	// returned preparationId.
	Prepare(ctx context.Context, in *PrepareJobRequest, opts ...grpc.CallOption) (*PrepareJobResponse, error)
	// Submit the job for execution
	Run(ctx context.Context, in *RunJobRequest, opts ...grpc.CallOption) (*RunJobResponse, error)
	// Get a list of all invoked jobs
	GetJobs(ctx context.Context, in *GetJobsRequest, opts ...grpc.CallOption) (*GetJobsResponse, error)
	// Get the current state of the job
	GetState(ctx context.Context, in *GetJobStateRequest, opts ...grpc.CallOption) (*JobStateEvent, error)
	// Get the job's pipeline
	GetPipeline(ctx context.Context, in *GetJobPipelineRequest, opts ...grpc.CallOption) (*GetJobPipelineResponse, error)
	// Cancel the job
	Cancel(ctx context.Context, in *CancelJobRequest, opts ...grpc.CallOption) (*CancelJobResponse, error)
	// Subscribe to a stream of state changes of the job, will immediately return the current state of the job as the first response.
	GetStateStream(ctx context.Context, in *GetJobStateRequest, opts ...grpc.CallOption) (JobService_GetStateStreamClient, error)
	// Subscribe to a stream of state changes and messages from the job
	GetMessageStream(ctx context.Context, in *JobMessagesRequest, opts ...grpc.CallOption) (JobService_GetMessageStreamClient, error)
	// Fetch metrics for a given job
	GetJobMetrics(ctx context.Context, in *GetJobMetricsRequest, opts ...grpc.CallOption) (*GetJobMetricsResponse, error)
	// Get the supported pipeline options of the runner
	DescribePipelineOptions(ctx context.Context, in *DescribePipelineOptionsRequest, opts ...grpc.CallOption) (*DescribePipelineOptionsResponse, error)
}

JobServiceClient is the client API for JobService service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream.

func NewJobServiceClient

func NewJobServiceClient(cc grpc.ClientConnInterface) JobServiceClient

type JobServiceServer

type JobServiceServer interface {
	// Prepare a job for execution. The job will not be executed until a call is made to run with the
	// returned preparationId.
	Prepare(context.Context, *PrepareJobRequest) (*PrepareJobResponse, error)
	// Submit the job for execution
	Run(context.Context, *RunJobRequest) (*RunJobResponse, error)
	// Get a list of all invoked jobs
	GetJobs(context.Context, *GetJobsRequest) (*GetJobsResponse, error)
	// Get the current state of the job
	GetState(context.Context, *GetJobStateRequest) (*JobStateEvent, error)
	// Get the job's pipeline
	GetPipeline(context.Context, *GetJobPipelineRequest) (*GetJobPipelineResponse, error)
	// Cancel the job
	Cancel(context.Context, *CancelJobRequest) (*CancelJobResponse, error)
	// Subscribe to a stream of state changes of the job, will immediately return the current state of the job as the first response.
	GetStateStream(*GetJobStateRequest, JobService_GetStateStreamServer) error
	// Subscribe to a stream of state changes and messages from the job
	GetMessageStream(*JobMessagesRequest, JobService_GetMessageStreamServer) error
	// Fetch metrics for a given job
	GetJobMetrics(context.Context, *GetJobMetricsRequest) (*GetJobMetricsResponse, error)
	// Get the supported pipeline options of the runner
	DescribePipelineOptions(context.Context, *DescribePipelineOptionsRequest) (*DescribePipelineOptionsResponse, error)
	// contains filtered or unexported methods
}

JobServiceServer is the server API for JobService service. All implementations must embed UnimplementedJobServiceServer for forward compatibility

type JobService_GetMessageStreamClient

type JobService_GetMessageStreamClient interface {
	Recv() (*JobMessagesResponse, error)
	grpc.ClientStream
}

type JobService_GetMessageStreamServer

type JobService_GetMessageStreamServer interface {
	Send(*JobMessagesResponse) error
	grpc.ServerStream
}

type JobService_GetStateStreamClient

type JobService_GetStateStreamClient interface {
	Recv() (*JobStateEvent, error)
	grpc.ClientStream
}

type JobService_GetStateStreamServer

type JobService_GetStateStreamServer interface {
	Send(*JobStateEvent) error
	grpc.ServerStream
}

type JobState

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

Enumeration of all JobStates

The state transition diagram is:

STOPPED -> STARTING -> RUNNING -> DONE
                               \> FAILED
                               \> CANCELLING -> CANCELLED
                               \> UPDATING -> UPDATED
                               \> DRAINING -> DRAINED

Transitions are optional such that a job may go from STOPPED to RUNNING without needing to pass through STARTING.

func (*JobState) Descriptor deprecated

func (*JobState) Descriptor() ([]byte, []int)

Deprecated: Use JobState.ProtoReflect.Descriptor instead.

func (*JobState) ProtoMessage

func (*JobState) ProtoMessage()

func (*JobState) ProtoReflect

func (x *JobState) ProtoReflect() protoreflect.Message

func (*JobState) Reset

func (x *JobState) Reset()

func (*JobState) String

func (x *JobState) String() string

type JobStateEvent

type JobStateEvent struct {
	State     JobState_Enum          `protobuf:"varint,1,opt,name=state,proto3,enum=org.apache.beam.model.job_management.v1.JobState_Enum" json:"state,omitempty"` // (required)
	Timestamp *timestamppb.Timestamp `protobuf:"bytes,2,opt,name=timestamp,proto3" json:"timestamp,omitempty"`                                                     // (required)
	// contains filtered or unexported fields
}

func (*JobStateEvent) Descriptor deprecated

func (*JobStateEvent) Descriptor() ([]byte, []int)

Deprecated: Use JobStateEvent.ProtoReflect.Descriptor instead.

func (*JobStateEvent) GetState

func (x *JobStateEvent) GetState() JobState_Enum

func (*JobStateEvent) GetTimestamp

func (x *JobStateEvent) GetTimestamp() *timestamppb.Timestamp

func (*JobStateEvent) ProtoMessage

func (*JobStateEvent) ProtoMessage()

func (*JobStateEvent) ProtoReflect

func (x *JobStateEvent) ProtoReflect() protoreflect.Message

func (*JobStateEvent) Reset

func (x *JobStateEvent) Reset()

func (*JobStateEvent) String

func (x *JobStateEvent) String() string

type JobState_Enum

type JobState_Enum int32
const (
	// The job state reported by a runner cannot be interpreted by the SDK.
	JobState_UNSPECIFIED JobState_Enum = 0
	// The job has not yet started.
	JobState_STOPPED JobState_Enum = 1
	// The job is currently running.
	JobState_RUNNING JobState_Enum = 2
	// The job has successfully completed. (terminal)
	JobState_DONE JobState_Enum = 3
	// The job has failed. (terminal)
	JobState_FAILED JobState_Enum = 4
	// The job has been explicitly cancelled. (terminal)
	JobState_CANCELLED JobState_Enum = 5
	// The job has been updated. (terminal)
	JobState_UPDATED JobState_Enum = 6
	// The job is draining its data. (optional)
	JobState_DRAINING JobState_Enum = 7
	// The job has completed draining its data. (terminal)
	JobState_DRAINED JobState_Enum = 8
	// The job is starting up.
	JobState_STARTING JobState_Enum = 9
	// The job is cancelling. (optional)
	JobState_CANCELLING JobState_Enum = 10
	// The job is in the process of being updated. (optional)
	JobState_UPDATING JobState_Enum = 11
)

func (JobState_Enum) Descriptor

func (JobState_Enum) Enum

func (x JobState_Enum) Enum() *JobState_Enum

func (JobState_Enum) EnumDescriptor deprecated

func (JobState_Enum) EnumDescriptor() ([]byte, []int)

Deprecated: Use JobState_Enum.Descriptor instead.

func (JobState_Enum) Number

func (JobState_Enum) String

func (x JobState_Enum) String() string

func (JobState_Enum) Type

type LegacyArtifactRetrievalServiceClient

type LegacyArtifactRetrievalServiceClient interface {
	// Get the manifest for the job
	GetManifest(ctx context.Context, in *GetManifestRequest, opts ...grpc.CallOption) (*GetManifestResponse, error)
	// Get an artifact staged for the job. The requested artifact must be within the manifest
	GetArtifact(ctx context.Context, in *LegacyGetArtifactRequest, opts ...grpc.CallOption) (LegacyArtifactRetrievalService_GetArtifactClient, error)
}

LegacyArtifactRetrievalServiceClient is the client API for LegacyArtifactRetrievalService service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream.

type LegacyArtifactRetrievalServiceServer

type LegacyArtifactRetrievalServiceServer interface {
	// Get the manifest for the job
	GetManifest(context.Context, *GetManifestRequest) (*GetManifestResponse, error)
	// Get an artifact staged for the job. The requested artifact must be within the manifest
	GetArtifact(*LegacyGetArtifactRequest, LegacyArtifactRetrievalService_GetArtifactServer) error
	// contains filtered or unexported methods
}

LegacyArtifactRetrievalServiceServer is the server API for LegacyArtifactRetrievalService service. All implementations must embed UnimplementedLegacyArtifactRetrievalServiceServer for forward compatibility

type LegacyArtifactRetrievalService_GetArtifactClient

type LegacyArtifactRetrievalService_GetArtifactClient interface {
	Recv() (*ArtifactChunk, error)
	grpc.ClientStream
}

type LegacyArtifactRetrievalService_GetArtifactServer

type LegacyArtifactRetrievalService_GetArtifactServer interface {
	Send(*ArtifactChunk) error
	grpc.ServerStream
}

type LegacyArtifactStagingServiceClient

type LegacyArtifactStagingServiceClient interface {
	// Stage an artifact to be available during job execution. The first request must contain the
	// name of the artifact. All future requests must contain sequential chunks of the content of
	// the artifact.
	PutArtifact(ctx context.Context, opts ...grpc.CallOption) (LegacyArtifactStagingService_PutArtifactClient, error)
	// Commit the manifest for a Job. All artifacts must have been successfully uploaded
	// before this call is made.
	//
	// Throws error INVALID_ARGUMENT if not all of the members of the manifest are present
	CommitManifest(ctx context.Context, in *CommitManifestRequest, opts ...grpc.CallOption) (*CommitManifestResponse, error)
}

LegacyArtifactStagingServiceClient is the client API for LegacyArtifactStagingService service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://pkg.go.dev/google.golang.org/grpc/?tab=doc#ClientConn.NewStream.

type LegacyArtifactStagingServiceServer

type LegacyArtifactStagingServiceServer interface {
	// Stage an artifact to be available during job execution. The first request must contain the
	// name of the artifact. All future requests must contain sequential chunks of the content of
	// the artifact.
	PutArtifact(LegacyArtifactStagingService_PutArtifactServer) error
	// Commit the manifest for a Job. All artifacts must have been successfully uploaded
	// before this call is made.
	//
	// Throws error INVALID_ARGUMENT if not all of the members of the manifest are present
	CommitManifest(context.Context, *CommitManifestRequest) (*CommitManifestResponse, error)
	// contains filtered or unexported methods
}

LegacyArtifactStagingServiceServer is the server API for LegacyArtifactStagingService service. All implementations must embed UnimplementedLegacyArtifactStagingServiceServer for forward compatibility

type LegacyArtifactStagingService_PutArtifactClient

type LegacyArtifactStagingService_PutArtifactClient interface {
	Send(*PutArtifactRequest) error
	CloseAndRecv() (*PutArtifactResponse, error)
	grpc.ClientStream
}

type LegacyArtifactStagingService_PutArtifactServer

type LegacyArtifactStagingService_PutArtifactServer interface {
	SendAndClose(*PutArtifactResponse) error
	Recv() (*PutArtifactRequest, error)
	grpc.ServerStream
}

type LegacyGetArtifactRequest

type LegacyGetArtifactRequest struct {

	// (Required) The name of the artifact to retrieve.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// (Required) An opaque token representing the entirety of the staged artifacts.
	// Returned in CommitManifestResponse.
	RetrievalToken string `protobuf:"bytes,2,opt,name=retrieval_token,json=retrievalToken,proto3" json:"retrieval_token,omitempty"`
	// contains filtered or unexported fields
}

A request to get an artifact. The artifact must be present in the manifest for the job.

func (*LegacyGetArtifactRequest) Descriptor deprecated

func (*LegacyGetArtifactRequest) Descriptor() ([]byte, []int)

Deprecated: Use LegacyGetArtifactRequest.ProtoReflect.Descriptor instead.

func (*LegacyGetArtifactRequest) GetName

func (x *LegacyGetArtifactRequest) GetName() string

func (*LegacyGetArtifactRequest) GetRetrievalToken

func (x *LegacyGetArtifactRequest) GetRetrievalToken() string

func (*LegacyGetArtifactRequest) ProtoMessage

func (*LegacyGetArtifactRequest) ProtoMessage()

func (*LegacyGetArtifactRequest) ProtoReflect

func (x *LegacyGetArtifactRequest) ProtoReflect() protoreflect.Message

func (*LegacyGetArtifactRequest) Reset

func (x *LegacyGetArtifactRequest) Reset()

func (*LegacyGetArtifactRequest) String

func (x *LegacyGetArtifactRequest) String() string

type Manifest

type Manifest struct {
	Artifact []*ArtifactMetadata `protobuf:"bytes,1,rep,name=artifact,proto3" json:"artifact,omitempty"`
	// contains filtered or unexported fields
}

A collection of artifacts.

func (*Manifest) Descriptor deprecated

func (*Manifest) Descriptor() ([]byte, []int)

Deprecated: Use Manifest.ProtoReflect.Descriptor instead.

func (*Manifest) GetArtifact

func (x *Manifest) GetArtifact() []*ArtifactMetadata

func (*Manifest) ProtoMessage

func (*Manifest) ProtoMessage()

func (*Manifest) ProtoReflect

func (x *Manifest) ProtoReflect() protoreflect.Message

func (*Manifest) Reset

func (x *Manifest) Reset()

func (*Manifest) String

func (x *Manifest) String() string

type MetricResults

type MetricResults struct {
	Attempted []*pipeline_v1.MonitoringInfo `protobuf:"bytes,1,rep,name=attempted,proto3" json:"attempted,omitempty"`
	Committed []*pipeline_v1.MonitoringInfo `protobuf:"bytes,2,rep,name=committed,proto3" json:"committed,omitempty"`
	// contains filtered or unexported fields
}

All metrics for a given job. Runners may support one or the other or both.

func (*MetricResults) Descriptor deprecated

func (*MetricResults) Descriptor() ([]byte, []int)

Deprecated: Use MetricResults.ProtoReflect.Descriptor instead.

func (*MetricResults) GetAttempted

func (x *MetricResults) GetAttempted() []*pipeline_v1.MonitoringInfo

func (*MetricResults) GetCommitted

func (x *MetricResults) GetCommitted() []*pipeline_v1.MonitoringInfo

func (*MetricResults) ProtoMessage

func (*MetricResults) ProtoMessage()

func (*MetricResults) ProtoReflect

func (x *MetricResults) ProtoReflect() protoreflect.Message

func (*MetricResults) Reset

func (x *MetricResults) Reset()

func (*MetricResults) String

func (x *MetricResults) String() string

type PipelineOptionDescriptor

type PipelineOptionDescriptor struct {

	// (Required) The option name.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// (Required) Type of option.
	Type PipelineOptionType_Enum `` /* 131-byte string literal not displayed */
	// (Optional) Description suitable for display / help text.
	Description string `protobuf:"bytes,3,opt,name=description,proto3" json:"description,omitempty"`
	// (Optional) Default value.
	DefaultValue string `protobuf:"bytes,4,opt,name=default_value,json=defaultValue,proto3" json:"default_value,omitempty"`
	// (Required) The group this option belongs to.
	Group string `protobuf:"bytes,5,opt,name=group,proto3" json:"group,omitempty"`
	// contains filtered or unexported fields
}

Metadata for a pipeline option.

func (*PipelineOptionDescriptor) Descriptor deprecated

func (*PipelineOptionDescriptor) Descriptor() ([]byte, []int)

Deprecated: Use PipelineOptionDescriptor.ProtoReflect.Descriptor instead.

func (*PipelineOptionDescriptor) GetDefaultValue

func (x *PipelineOptionDescriptor) GetDefaultValue() string

func (*PipelineOptionDescriptor) GetDescription

func (x *PipelineOptionDescriptor) GetDescription() string

func (*PipelineOptionDescriptor) GetGroup

func (x *PipelineOptionDescriptor) GetGroup() string

func (*PipelineOptionDescriptor) GetName

func (x *PipelineOptionDescriptor) GetName() string

func (*PipelineOptionDescriptor) GetType

func (*PipelineOptionDescriptor) ProtoMessage

func (*PipelineOptionDescriptor) ProtoMessage()

func (*PipelineOptionDescriptor) ProtoReflect

func (x *PipelineOptionDescriptor) ProtoReflect() protoreflect.Message

func (*PipelineOptionDescriptor) Reset

func (x *PipelineOptionDescriptor) Reset()

func (*PipelineOptionDescriptor) String

func (x *PipelineOptionDescriptor) String() string

type PipelineOptionType

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

Type for pipeline options. Types mirror those of JSON, since that's how pipeline options are serialized.

func (*PipelineOptionType) Descriptor deprecated

func (*PipelineOptionType) Descriptor() ([]byte, []int)

Deprecated: Use PipelineOptionType.ProtoReflect.Descriptor instead.

func (*PipelineOptionType) ProtoMessage

func (*PipelineOptionType) ProtoMessage()

func (*PipelineOptionType) ProtoReflect

func (x *PipelineOptionType) ProtoReflect() protoreflect.Message

func (*PipelineOptionType) Reset

func (x *PipelineOptionType) Reset()

func (*PipelineOptionType) String

func (x *PipelineOptionType) String() string

type PipelineOptionType_Enum

type PipelineOptionType_Enum int32
const (
	PipelineOptionType_STRING  PipelineOptionType_Enum = 0
	PipelineOptionType_BOOLEAN PipelineOptionType_Enum = 1
	// whole numbers, see https://json-schema.org/understanding-json-schema/reference/numeric.html
	PipelineOptionType_INTEGER PipelineOptionType_Enum = 2
	PipelineOptionType_NUMBER  PipelineOptionType_Enum = 3
	PipelineOptionType_ARRAY   PipelineOptionType_Enum = 4
	PipelineOptionType_OBJECT  PipelineOptionType_Enum = 5
)

func (PipelineOptionType_Enum) Descriptor

func (PipelineOptionType_Enum) Enum

func (PipelineOptionType_Enum) EnumDescriptor deprecated

func (PipelineOptionType_Enum) EnumDescriptor() ([]byte, []int)

Deprecated: Use PipelineOptionType_Enum.Descriptor instead.

func (PipelineOptionType_Enum) Number

func (PipelineOptionType_Enum) String

func (x PipelineOptionType_Enum) String() string

func (PipelineOptionType_Enum) Type

type PrepareJobRequest

type PrepareJobRequest struct {
	Pipeline        *pipeline_v1.Pipeline `protobuf:"bytes,1,opt,name=pipeline,proto3" json:"pipeline,omitempty"`                                      // (required)
	PipelineOptions *structpb.Struct      `protobuf:"bytes,2,opt,name=pipeline_options,json=pipelineOptions,proto3" json:"pipeline_options,omitempty"` // (required)
	JobName         string                `protobuf:"bytes,3,opt,name=job_name,json=jobName,proto3" json:"job_name,omitempty"`                         // (required)
	// contains filtered or unexported fields
}

Prepare is a synchronous request that returns a preparationId back Throws error GRPC_STATUS_UNAVAILABLE if server is down Throws error ALREADY_EXISTS if the jobName is reused. Runners are permitted to deduplicate based on the name of the job. Throws error UNKNOWN for all other issues

func (*PrepareJobRequest) Descriptor deprecated

func (*PrepareJobRequest) Descriptor() ([]byte, []int)

Deprecated: Use PrepareJobRequest.ProtoReflect.Descriptor instead.

func (*PrepareJobRequest) GetJobName

func (x *PrepareJobRequest) GetJobName() string

func (*PrepareJobRequest) GetPipeline

func (x *PrepareJobRequest) GetPipeline() *pipeline_v1.Pipeline

func (*PrepareJobRequest) GetPipelineOptions

func (x *PrepareJobRequest) GetPipelineOptions() *structpb.Struct

func (*PrepareJobRequest) ProtoMessage

func (*PrepareJobRequest) ProtoMessage()

func (*PrepareJobRequest) ProtoReflect

func (x *PrepareJobRequest) ProtoReflect() protoreflect.Message

func (*PrepareJobRequest) Reset

func (x *PrepareJobRequest) Reset()

func (*PrepareJobRequest) String

func (x *PrepareJobRequest) String() string

type PrepareJobResponse

type PrepareJobResponse struct {

	// (required) The ID used to associate calls made while preparing the job. preparationId is used
	// to run the job.
	PreparationId string `protobuf:"bytes,1,opt,name=preparation_id,json=preparationId,proto3" json:"preparation_id,omitempty"`
	// An endpoint which exposes the Beam Artifact Staging API. Artifacts used by the job should be
	// staged to this endpoint, and will be available during job execution.
	ArtifactStagingEndpoint *pipeline_v1.ApiServiceDescriptor `` /* 132-byte string literal not displayed */
	// (required) Token for the artifact staging. This token also represent an artifact
	// staging session with the artifact staging service.
	StagingSessionToken string `protobuf:"bytes,3,opt,name=staging_session_token,json=stagingSessionToken,proto3" json:"staging_session_token,omitempty"`
	// contains filtered or unexported fields
}

func (*PrepareJobResponse) Descriptor deprecated

func (*PrepareJobResponse) Descriptor() ([]byte, []int)

Deprecated: Use PrepareJobResponse.ProtoReflect.Descriptor instead.

func (*PrepareJobResponse) GetArtifactStagingEndpoint

func (x *PrepareJobResponse) GetArtifactStagingEndpoint() *pipeline_v1.ApiServiceDescriptor

func (*PrepareJobResponse) GetPreparationId

func (x *PrepareJobResponse) GetPreparationId() string

func (*PrepareJobResponse) GetStagingSessionToken

func (x *PrepareJobResponse) GetStagingSessionToken() string

func (*PrepareJobResponse) ProtoMessage

func (*PrepareJobResponse) ProtoMessage()

func (*PrepareJobResponse) ProtoReflect

func (x *PrepareJobResponse) ProtoReflect() protoreflect.Message

func (*PrepareJobResponse) Reset

func (x *PrepareJobResponse) Reset()

func (*PrepareJobResponse) String

func (x *PrepareJobResponse) String() string

type ProxyManifest

type ProxyManifest struct {
	Manifest *Manifest                 `protobuf:"bytes,1,opt,name=manifest,proto3" json:"manifest,omitempty"`
	Location []*ProxyManifest_Location `protobuf:"bytes,2,rep,name=location,proto3" json:"location,omitempty"`
	// contains filtered or unexported fields
}

A manifest with location information.

func (*ProxyManifest) Descriptor deprecated

func (*ProxyManifest) Descriptor() ([]byte, []int)

Deprecated: Use ProxyManifest.ProtoReflect.Descriptor instead.

func (*ProxyManifest) GetLocation

func (x *ProxyManifest) GetLocation() []*ProxyManifest_Location

func (*ProxyManifest) GetManifest

func (x *ProxyManifest) GetManifest() *Manifest

func (*ProxyManifest) ProtoMessage

func (*ProxyManifest) ProtoMessage()

func (*ProxyManifest) ProtoReflect

func (x *ProxyManifest) ProtoReflect() protoreflect.Message

func (*ProxyManifest) Reset

func (x *ProxyManifest) Reset()

func (*ProxyManifest) String

func (x *ProxyManifest) String() string

type ProxyManifest_Location

type ProxyManifest_Location struct {
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	Uri  string `protobuf:"bytes,2,opt,name=uri,proto3" json:"uri,omitempty"`
	// contains filtered or unexported fields
}

func (*ProxyManifest_Location) Descriptor deprecated

func (*ProxyManifest_Location) Descriptor() ([]byte, []int)

Deprecated: Use ProxyManifest_Location.ProtoReflect.Descriptor instead.

func (*ProxyManifest_Location) GetName

func (x *ProxyManifest_Location) GetName() string

func (*ProxyManifest_Location) GetUri

func (x *ProxyManifest_Location) GetUri() string

func (*ProxyManifest_Location) ProtoMessage

func (*ProxyManifest_Location) ProtoMessage()

func (*ProxyManifest_Location) ProtoReflect

func (x *ProxyManifest_Location) ProtoReflect() protoreflect.Message

func (*ProxyManifest_Location) Reset

func (x *ProxyManifest_Location) Reset()

func (*ProxyManifest_Location) String

func (x *ProxyManifest_Location) String() string

type PutArtifactMetadata

type PutArtifactMetadata struct {

	// (Required) A token for artifact staging session. This token can be obtained
	// from PrepareJob request in JobService
	StagingSessionToken string `protobuf:"bytes,1,opt,name=staging_session_token,json=stagingSessionToken,proto3" json:"staging_session_token,omitempty"`
	// (Required) The Artifact metadata.
	Metadata *ArtifactMetadata `protobuf:"bytes,2,opt,name=metadata,proto3" json:"metadata,omitempty"`
	// contains filtered or unexported fields
}

func (*PutArtifactMetadata) Descriptor deprecated

func (*PutArtifactMetadata) Descriptor() ([]byte, []int)

Deprecated: Use PutArtifactMetadata.ProtoReflect.Descriptor instead.

func (*PutArtifactMetadata) GetMetadata

func (x *PutArtifactMetadata) GetMetadata() *ArtifactMetadata

func (*PutArtifactMetadata) GetStagingSessionToken

func (x *PutArtifactMetadata) GetStagingSessionToken() string

func (*PutArtifactMetadata) ProtoMessage

func (*PutArtifactMetadata) ProtoMessage()

func (*PutArtifactMetadata) ProtoReflect

func (x *PutArtifactMetadata) ProtoReflect() protoreflect.Message

func (*PutArtifactMetadata) Reset

func (x *PutArtifactMetadata) Reset()

func (*PutArtifactMetadata) String

func (x *PutArtifactMetadata) String() string

type PutArtifactRequest

type PutArtifactRequest struct {

	// (Required)
	//
	// Types that are assignable to Content:
	//	*PutArtifactRequest_Metadata
	//	*PutArtifactRequest_Data
	Content isPutArtifactRequest_Content `protobuf_oneof:"content"`
	// contains filtered or unexported fields
}

A request to stage an artifact.

func (*PutArtifactRequest) Descriptor deprecated

func (*PutArtifactRequest) Descriptor() ([]byte, []int)

Deprecated: Use PutArtifactRequest.ProtoReflect.Descriptor instead.

func (*PutArtifactRequest) GetContent

func (m *PutArtifactRequest) GetContent() isPutArtifactRequest_Content

func (*PutArtifactRequest) GetData

func (x *PutArtifactRequest) GetData() *ArtifactChunk

func (*PutArtifactRequest) GetMetadata

func (x *PutArtifactRequest) GetMetadata() *PutArtifactMetadata

func (*PutArtifactRequest) ProtoMessage

func (*PutArtifactRequest) ProtoMessage()

func (*PutArtifactRequest) ProtoReflect

func (x *PutArtifactRequest) ProtoReflect() protoreflect.Message

func (*PutArtifactRequest) Reset

func (x *PutArtifactRequest) Reset()

func (*PutArtifactRequest) String

func (x *PutArtifactRequest) String() string

type PutArtifactRequest_Data

type PutArtifactRequest_Data struct {
	// A chunk of the artifact. All messages after the first in a PutArtifact call must contain a
	// chunk.
	Data *ArtifactChunk `protobuf:"bytes,2,opt,name=data,proto3,oneof"`
}

type PutArtifactRequest_Metadata

type PutArtifactRequest_Metadata struct {
	// The first message in a PutArtifact call must contain this field.
	Metadata *PutArtifactMetadata `protobuf:"bytes,1,opt,name=metadata,proto3,oneof"`
}

type PutArtifactResponse

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

func (*PutArtifactResponse) Descriptor deprecated

func (*PutArtifactResponse) Descriptor() ([]byte, []int)

Deprecated: Use PutArtifactResponse.ProtoReflect.Descriptor instead.

func (*PutArtifactResponse) ProtoMessage

func (*PutArtifactResponse) ProtoMessage()

func (*PutArtifactResponse) ProtoReflect

func (x *PutArtifactResponse) ProtoReflect() protoreflect.Message

func (*PutArtifactResponse) Reset

func (x *PutArtifactResponse) Reset()

func (*PutArtifactResponse) String

func (x *PutArtifactResponse) String() string

type ResolveArtifactsRequest

type ResolveArtifactsRequest struct {

	// An (ordered) set of artifacts to (jointly) resolve.
	Artifacts []*pipeline_v1.ArtifactInformation `protobuf:"bytes,1,rep,name=artifacts,proto3" json:"artifacts,omitempty"`
	// A set of artifact type urns that are understood by the requester.
	// An attempt should be made to resolve the artifacts in terms of these URNs,
	// but other URNs may be used as well with the understanding that they must
	// be fetch-able as bytes via GetArtifact.
	PreferredUrns []string `protobuf:"bytes,2,rep,name=preferred_urns,json=preferredUrns,proto3" json:"preferred_urns,omitempty"`
	// contains filtered or unexported fields
}

A request for artifact resolution.

func (*ResolveArtifactsRequest) Descriptor deprecated

func (*ResolveArtifactsRequest) Descriptor() ([]byte, []int)

Deprecated: Use ResolveArtifactsRequest.ProtoReflect.Descriptor instead.

func (*ResolveArtifactsRequest) GetArtifacts

func (*ResolveArtifactsRequest) GetPreferredUrns

func (x *ResolveArtifactsRequest) GetPreferredUrns() []string

func (*ResolveArtifactsRequest) ProtoMessage

func (*ResolveArtifactsRequest) ProtoMessage()

func (*ResolveArtifactsRequest) ProtoReflect

func (x *ResolveArtifactsRequest) ProtoReflect() protoreflect.Message

func (*ResolveArtifactsRequest) Reset

func (x *ResolveArtifactsRequest) Reset()

func (*ResolveArtifactsRequest) String

func (x *ResolveArtifactsRequest) String() string

type ResolveArtifactsResponse

type ResolveArtifactsResponse struct {

	// A full (ordered) set of replacements for the set of requested artifacts,
	// preferably in terms of the requested type URNs.  If there is no better
	// resolution, the original list is returned.
	Replacements []*pipeline_v1.ArtifactInformation `protobuf:"bytes,1,rep,name=replacements,proto3" json:"replacements,omitempty"`
	// contains filtered or unexported fields
}

A response for artifact resolution.

func (*ResolveArtifactsResponse) Descriptor deprecated

func (*ResolveArtifactsResponse) Descriptor() ([]byte, []int)

Deprecated: Use ResolveArtifactsResponse.ProtoReflect.Descriptor instead.

func (*ResolveArtifactsResponse) GetReplacements

func (*ResolveArtifactsResponse) ProtoMessage

func (*ResolveArtifactsResponse) ProtoMessage()

func (*ResolveArtifactsResponse) ProtoReflect

func (x *ResolveArtifactsResponse) ProtoReflect() protoreflect.Message

func (*ResolveArtifactsResponse) Reset

func (x *ResolveArtifactsResponse) Reset()

func (*ResolveArtifactsResponse) String

func (x *ResolveArtifactsResponse) String() string

type RunJobRequest

type RunJobRequest struct {

	// (required) The ID provided by an earlier call to prepare. Runs the job. All prerequisite tasks
	// must have been completed.
	PreparationId string `protobuf:"bytes,1,opt,name=preparation_id,json=preparationId,proto3" json:"preparation_id,omitempty"`
	// (optional) If any artifacts have been staged for this job, contains the retrieval_token returned
	// from the CommitManifestResponse.
	RetrievalToken string `protobuf:"bytes,2,opt,name=retrieval_token,json=retrievalToken,proto3" json:"retrieval_token,omitempty"`
	// contains filtered or unexported fields
}

Run is a synchronous request that returns a jobId back. Throws error GRPC_STATUS_UNAVAILABLE if server is down Throws error NOT_FOUND if the preparation ID does not exist Throws error UNKNOWN for all other issues

func (*RunJobRequest) Descriptor deprecated

func (*RunJobRequest) Descriptor() ([]byte, []int)

Deprecated: Use RunJobRequest.ProtoReflect.Descriptor instead.

func (*RunJobRequest) GetPreparationId

func (x *RunJobRequest) GetPreparationId() string

func (*RunJobRequest) GetRetrievalToken

func (x *RunJobRequest) GetRetrievalToken() string

func (*RunJobRequest) ProtoMessage

func (*RunJobRequest) ProtoMessage()

func (*RunJobRequest) ProtoReflect

func (x *RunJobRequest) ProtoReflect() protoreflect.Message

func (*RunJobRequest) Reset

func (x *RunJobRequest) Reset()

func (*RunJobRequest) String

func (x *RunJobRequest) String() string

type RunJobResponse

type RunJobResponse struct {
	JobId string `protobuf:"bytes,1,opt,name=job_id,json=jobId,proto3" json:"job_id,omitempty"` // (required) The ID for the executing job
	// contains filtered or unexported fields
}

func (*RunJobResponse) Descriptor deprecated

func (*RunJobResponse) Descriptor() ([]byte, []int)

Deprecated: Use RunJobResponse.ProtoReflect.Descriptor instead.

func (*RunJobResponse) GetJobId

func (x *RunJobResponse) GetJobId() string

func (*RunJobResponse) ProtoMessage

func (*RunJobResponse) ProtoMessage()

func (*RunJobResponse) ProtoReflect

func (x *RunJobResponse) ProtoReflect() protoreflect.Message

func (*RunJobResponse) Reset

func (x *RunJobResponse) Reset()

func (*RunJobResponse) String

func (x *RunJobResponse) String() string

type UnimplementedArtifactRetrievalServiceServer

type UnimplementedArtifactRetrievalServiceServer struct {
}

UnimplementedArtifactRetrievalServiceServer must be embedded to have forward compatible implementations.

func (UnimplementedArtifactRetrievalServiceServer) ResolveArtifacts

type UnimplementedArtifactStagingServiceServer

type UnimplementedArtifactStagingServiceServer struct {
}

UnimplementedArtifactStagingServiceServer must be embedded to have forward compatible implementations.

func (UnimplementedArtifactStagingServiceServer) ReverseArtifactRetrievalService

type UnimplementedExpansionServiceServer

type UnimplementedExpansionServiceServer struct {
}

UnimplementedExpansionServiceServer must be embedded to have forward compatible implementations.

func (UnimplementedExpansionServiceServer) Expand

type UnimplementedJobServiceServer

type UnimplementedJobServiceServer struct {
}

UnimplementedJobServiceServer must be embedded to have forward compatible implementations.

func (UnimplementedJobServiceServer) Cancel

func (UnimplementedJobServiceServer) GetJobMetrics

func (UnimplementedJobServiceServer) GetJobs

func (UnimplementedJobServiceServer) GetMessageStream

func (UnimplementedJobServiceServer) GetPipeline

func (UnimplementedJobServiceServer) GetState

func (UnimplementedJobServiceServer) GetStateStream

func (UnimplementedJobServiceServer) Prepare

func (UnimplementedJobServiceServer) Run

type UnimplementedLegacyArtifactRetrievalServiceServer

type UnimplementedLegacyArtifactRetrievalServiceServer struct {
}

UnimplementedLegacyArtifactRetrievalServiceServer must be embedded to have forward compatible implementations.

func (UnimplementedLegacyArtifactRetrievalServiceServer) GetManifest

type UnimplementedLegacyArtifactStagingServiceServer

type UnimplementedLegacyArtifactStagingServiceServer struct {
}

UnimplementedLegacyArtifactStagingServiceServer must be embedded to have forward compatible implementations.

func (UnimplementedLegacyArtifactStagingServiceServer) CommitManifest

func (UnimplementedLegacyArtifactStagingServiceServer) PutArtifact

type UnsafeArtifactRetrievalServiceServer

type UnsafeArtifactRetrievalServiceServer interface {
	// contains filtered or unexported methods
}

UnsafeArtifactRetrievalServiceServer may be embedded to opt out of forward compatibility for this service. Use of this interface is not recommended, as added methods to ArtifactRetrievalServiceServer will result in compilation errors.

type UnsafeArtifactStagingServiceServer

type UnsafeArtifactStagingServiceServer interface {
	// contains filtered or unexported methods
}

UnsafeArtifactStagingServiceServer may be embedded to opt out of forward compatibility for this service. Use of this interface is not recommended, as added methods to ArtifactStagingServiceServer will result in compilation errors.

type UnsafeExpansionServiceServer

type UnsafeExpansionServiceServer interface {
	// contains filtered or unexported methods
}

UnsafeExpansionServiceServer may be embedded to opt out of forward compatibility for this service. Use of this interface is not recommended, as added methods to ExpansionServiceServer will result in compilation errors.

type UnsafeJobServiceServer

type UnsafeJobServiceServer interface {
	// contains filtered or unexported methods
}

UnsafeJobServiceServer may be embedded to opt out of forward compatibility for this service. Use of this interface is not recommended, as added methods to JobServiceServer will result in compilation errors.

type UnsafeLegacyArtifactRetrievalServiceServer

type UnsafeLegacyArtifactRetrievalServiceServer interface {
	// contains filtered or unexported methods
}

UnsafeLegacyArtifactRetrievalServiceServer may be embedded to opt out of forward compatibility for this service. Use of this interface is not recommended, as added methods to LegacyArtifactRetrievalServiceServer will result in compilation errors.

type UnsafeLegacyArtifactStagingServiceServer

type UnsafeLegacyArtifactStagingServiceServer interface {
	// contains filtered or unexported methods
}

UnsafeLegacyArtifactStagingServiceServer may be embedded to opt out of forward compatibility for this service. Use of this interface is not recommended, as added methods to LegacyArtifactStagingServiceServer will result in compilation errors.

Jump to

Keyboard shortcuts

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