fnexecution_v1

package
v2.32.0+incompatible Latest Latest
Warning

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

Go to latest
Published: Aug 10, 2021 License: Apache-2.0, BSD-3-Clause, MIT Imports: 13 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

View Source
var (
	LogEntry_Severity_Enum_name = map[int32]string{
		0: "UNSPECIFIED",
		1: "TRACE",
		2: "DEBUG",
		3: "INFO",
		4: "NOTICE",
		5: "WARN",
		6: "ERROR",
		7: "CRITICAL",
	}
	LogEntry_Severity_Enum_value = map[string]int32{
		"UNSPECIFIED": 0,
		"TRACE":       1,
		"DEBUG":       2,
		"INFO":        3,
		"NOTICE":      4,
		"WARN":        5,
		"ERROR":       6,
		"CRITICAL":    7,
	}
)

Enum value maps for LogEntry_Severity_Enum.

View Source
var File_beam_fn_api_proto protoreflect.FileDescriptor
View Source
var File_beam_provision_api_proto protoreflect.FileDescriptor

Functions

func RegisterBeamFnControlServer

func RegisterBeamFnControlServer(s *grpc.Server, srv BeamFnControlServer)

func RegisterBeamFnDataServer

func RegisterBeamFnDataServer(s *grpc.Server, srv BeamFnDataServer)

func RegisterBeamFnExternalWorkerPoolServer

func RegisterBeamFnExternalWorkerPoolServer(s *grpc.Server, srv BeamFnExternalWorkerPoolServer)

func RegisterBeamFnLoggingServer

func RegisterBeamFnLoggingServer(s *grpc.Server, srv BeamFnLoggingServer)

func RegisterBeamFnStateServer

func RegisterBeamFnStateServer(s *grpc.Server, srv BeamFnStateServer)

func RegisterBeamFnWorkerStatusServer

func RegisterBeamFnWorkerStatusServer(s *grpc.Server, srv BeamFnWorkerStatusServer)

func RegisterProvisionServiceServer

func RegisterProvisionServiceServer(s *grpc.Server, srv ProvisionServiceServer)

Types

type BeamFnControlClient

type BeamFnControlClient interface {
	// Instructions sent by the runner to the SDK requesting different types
	// of work.
	Control(ctx context.Context, opts ...grpc.CallOption) (BeamFnControl_ControlClient, error)
	// Used to get the full process bundle descriptors for bundles one
	// is asked to process.
	GetProcessBundleDescriptor(ctx context.Context, in *GetProcessBundleDescriptorRequest, opts ...grpc.CallOption) (*ProcessBundleDescriptor, error)
}

BeamFnControlClient is the client API for BeamFnControl service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

type BeamFnControlServer

type BeamFnControlServer interface {
	// Instructions sent by the runner to the SDK requesting different types
	// of work.
	Control(BeamFnControl_ControlServer) error
	// Used to get the full process bundle descriptors for bundles one
	// is asked to process.
	GetProcessBundleDescriptor(context.Context, *GetProcessBundleDescriptorRequest) (*ProcessBundleDescriptor, error)
}

BeamFnControlServer is the server API for BeamFnControl service.

type BeamFnControl_ControlClient

type BeamFnControl_ControlClient interface {
	Send(*InstructionResponse) error
	Recv() (*InstructionRequest, error)
	grpc.ClientStream
}

type BeamFnControl_ControlServer

type BeamFnControl_ControlServer interface {
	Send(*InstructionRequest) error
	Recv() (*InstructionResponse, error)
	grpc.ServerStream
}

type BeamFnDataClient

type BeamFnDataClient interface {
	// Used to send data between harnesses.
	Data(ctx context.Context, opts ...grpc.CallOption) (BeamFnData_DataClient, error)
}

BeamFnDataClient is the client API for BeamFnData service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

func NewBeamFnDataClient

func NewBeamFnDataClient(cc grpc.ClientConnInterface) BeamFnDataClient

type BeamFnDataServer

type BeamFnDataServer interface {
	// Used to send data between harnesses.
	Data(BeamFnData_DataServer) error
}

BeamFnDataServer is the server API for BeamFnData service.

type BeamFnData_DataClient

type BeamFnData_DataClient interface {
	Send(*Elements) error
	Recv() (*Elements, error)
	grpc.ClientStream
}

type BeamFnData_DataServer

type BeamFnData_DataServer interface {
	Send(*Elements) error
	Recv() (*Elements, error)
	grpc.ServerStream
}

type BeamFnExternalWorkerPoolClient

type BeamFnExternalWorkerPoolClient interface {
	// Start the SDK worker with the given ID.
	StartWorker(ctx context.Context, in *StartWorkerRequest, opts ...grpc.CallOption) (*StartWorkerResponse, error)
	// Stop the SDK worker.
	StopWorker(ctx context.Context, in *StopWorkerRequest, opts ...grpc.CallOption) (*StopWorkerResponse, error)
}

BeamFnExternalWorkerPoolClient is the client API for BeamFnExternalWorkerPool service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

type BeamFnExternalWorkerPoolServer

type BeamFnExternalWorkerPoolServer interface {
	// Start the SDK worker with the given ID.
	StartWorker(context.Context, *StartWorkerRequest) (*StartWorkerResponse, error)
	// Stop the SDK worker.
	StopWorker(context.Context, *StopWorkerRequest) (*StopWorkerResponse, error)
}

BeamFnExternalWorkerPoolServer is the server API for BeamFnExternalWorkerPool service.

type BeamFnLoggingClient

type BeamFnLoggingClient interface {
	// Allows for the SDK to emit log entries which the runner can
	// associate with the active job.
	Logging(ctx context.Context, opts ...grpc.CallOption) (BeamFnLogging_LoggingClient, error)
}

BeamFnLoggingClient is the client API for BeamFnLogging service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

type BeamFnLoggingServer

type BeamFnLoggingServer interface {
	// Allows for the SDK to emit log entries which the runner can
	// associate with the active job.
	Logging(BeamFnLogging_LoggingServer) error
}

BeamFnLoggingServer is the server API for BeamFnLogging service.

type BeamFnLogging_LoggingClient

type BeamFnLogging_LoggingClient interface {
	Send(*LogEntry_List) error
	Recv() (*LogControl, error)
	grpc.ClientStream
}

type BeamFnLogging_LoggingServer

type BeamFnLogging_LoggingServer interface {
	Send(*LogControl) error
	Recv() (*LogEntry_List, error)
	grpc.ServerStream
}

type BeamFnStateClient

type BeamFnStateClient interface {
	// Used to get/append/clear state stored by the runner on behalf of the SDK.
	State(ctx context.Context, opts ...grpc.CallOption) (BeamFnState_StateClient, error)
}

BeamFnStateClient is the client API for BeamFnState service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

type BeamFnStateServer

type BeamFnStateServer interface {
	// Used to get/append/clear state stored by the runner on behalf of the SDK.
	State(BeamFnState_StateServer) error
}

BeamFnStateServer is the server API for BeamFnState service.

type BeamFnState_StateClient

type BeamFnState_StateClient interface {
	Send(*StateRequest) error
	Recv() (*StateResponse, error)
	grpc.ClientStream
}

type BeamFnState_StateServer

type BeamFnState_StateServer interface {
	Send(*StateResponse) error
	Recv() (*StateRequest, error)
	grpc.ServerStream
}

type BeamFnWorkerStatusClient

type BeamFnWorkerStatusClient interface {
	WorkerStatus(ctx context.Context, opts ...grpc.CallOption) (BeamFnWorkerStatus_WorkerStatusClient, error)
}

BeamFnWorkerStatusClient is the client API for BeamFnWorkerStatus service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

type BeamFnWorkerStatusServer

type BeamFnWorkerStatusServer interface {
	WorkerStatus(BeamFnWorkerStatus_WorkerStatusServer) error
}

BeamFnWorkerStatusServer is the server API for BeamFnWorkerStatus service.

type BeamFnWorkerStatus_WorkerStatusClient

type BeamFnWorkerStatus_WorkerStatusClient interface {
	Send(*WorkerStatusResponse) error
	Recv() (*WorkerStatusRequest, error)
	grpc.ClientStream
}

type BeamFnWorkerStatus_WorkerStatusServer

type BeamFnWorkerStatus_WorkerStatusServer interface {
	Send(*WorkerStatusRequest) error
	Recv() (*WorkerStatusResponse, error)
	grpc.ServerStream
}

type BundleApplication

type BundleApplication struct {

	// (Required) The transform to which to pass the element
	TransformId string `protobuf:"bytes,1,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Required) Name of the transform's input to which to pass the element.
	InputId string `protobuf:"bytes,2,opt,name=input_id,json=inputId,proto3" json:"input_id,omitempty"`
	// (Required) The encoded element to pass to the transform.
	Element []byte `protobuf:"bytes,3,opt,name=element,proto3" json:"element,omitempty"`
	// The map is keyed by the local output name of the PTransform. Each
	// value represents a lower bound on the timestamps of elements that
	// are produced by this PTransform into each of its output PCollections
	// when invoked with this application.
	//
	// If there is no watermark reported from RestrictionTracker, the runner will
	// use MIN_TIMESTAMP by default.
	OutputWatermarks map[string]*timestamp.Timestamp `` /* 197-byte string literal not displayed */
	// Whether this application potentially produces an unbounded
	// amount of data. Note that this should only be set to BOUNDED if and
	// only if the application is known to produce a finite amount of output.
	IsBounded pipeline_v1.IsBounded_Enum `` /* 143-byte string literal not displayed */
	// contains filtered or unexported fields
}

One of the applications specifying the scope of work for a bundle. See https://docs.google.com/document/d/1tUDb45sStdR8u7-jBkGdw3OGFK7aa2-V7eo86zYSE_4/edit#heading=h.9g3g5weg2u9 for further details.

func (*BundleApplication) Descriptor deprecated

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

Deprecated: Use BundleApplication.ProtoReflect.Descriptor instead.

func (*BundleApplication) GetElement

func (x *BundleApplication) GetElement() []byte

func (*BundleApplication) GetInputId

func (x *BundleApplication) GetInputId() string

func (*BundleApplication) GetIsBounded

func (x *BundleApplication) GetIsBounded() pipeline_v1.IsBounded_Enum

func (*BundleApplication) GetOutputWatermarks

func (x *BundleApplication) GetOutputWatermarks() map[string]*timestamp.Timestamp

func (*BundleApplication) GetTransformId

func (x *BundleApplication) GetTransformId() string

func (*BundleApplication) ProtoMessage

func (*BundleApplication) ProtoMessage()

func (*BundleApplication) ProtoReflect

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

func (*BundleApplication) Reset

func (x *BundleApplication) Reset()

func (*BundleApplication) String

func (x *BundleApplication) String() string

type DelayedBundleApplication

type DelayedBundleApplication struct {

	// (Required) The application that should be scheduled.
	Application *BundleApplication `protobuf:"bytes,1,opt,name=application,proto3" json:"application,omitempty"`
	// Recommended time delay at which the application should be scheduled to
	// execute by the runner. Time delay that equals 0 may be scheduled to execute
	// immediately. The unit of time delay should be microsecond.
	RequestedTimeDelay *duration.Duration `protobuf:"bytes,2,opt,name=requested_time_delay,json=requestedTimeDelay,proto3" json:"requested_time_delay,omitempty"`
	// contains filtered or unexported fields
}

An Application should be scheduled for execution after a delay. Either an absolute timestamp or a relative timestamp can represent a scheduled execution time.

func (*DelayedBundleApplication) Descriptor deprecated

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

Deprecated: Use DelayedBundleApplication.ProtoReflect.Descriptor instead.

func (*DelayedBundleApplication) GetApplication

func (x *DelayedBundleApplication) GetApplication() *BundleApplication

func (*DelayedBundleApplication) GetRequestedTimeDelay

func (x *DelayedBundleApplication) GetRequestedTimeDelay() *duration.Duration

func (*DelayedBundleApplication) ProtoMessage

func (*DelayedBundleApplication) ProtoMessage()

func (*DelayedBundleApplication) ProtoReflect

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

func (*DelayedBundleApplication) Reset

func (x *DelayedBundleApplication) Reset()

func (*DelayedBundleApplication) String

func (x *DelayedBundleApplication) String() string

type Elements

type Elements struct {

	// (Optional) A list containing parts of logical byte streams.
	Data []*Elements_Data `protobuf:"bytes,1,rep,name=data,proto3" json:"data,omitempty"`
	// (Optional)  A list of timer byte streams.
	Timers []*Elements_Timers `protobuf:"bytes,2,rep,name=timers,proto3" json:"timers,omitempty"`
	// contains filtered or unexported fields
}

Messages used to represent logical byte streams. Stable

func (*Elements) Descriptor deprecated

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

Deprecated: Use Elements.ProtoReflect.Descriptor instead.

func (*Elements) GetData

func (x *Elements) GetData() []*Elements_Data

func (*Elements) GetTimers

func (x *Elements) GetTimers() []*Elements_Timers

func (*Elements) ProtoMessage

func (*Elements) ProtoMessage()

func (*Elements) ProtoReflect

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

func (*Elements) Reset

func (x *Elements) Reset()

func (*Elements) String

func (x *Elements) String() string

type Elements_Data

type Elements_Data struct {

	// (Required) A reference to an active instruction request with the given
	// instruction id.
	InstructionId string `protobuf:"bytes,1,opt,name=instruction_id,json=instructionId,proto3" json:"instruction_id,omitempty"`
	// (Required) A definition representing a consumer or producer of this data.
	// If received by a harness, this represents the consumer within that
	// harness that should consume these bytes. If sent by a harness, this
	// represents the producer of these bytes.
	//
	// Note that a single element may span multiple Data messages.
	//
	// Note that a sending/receiving pair should share the same identifier.
	TransformId string `protobuf:"bytes,2,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Optional) Represents a part of a logical byte stream. Elements within
	// the logical byte stream are encoded in the nested context and
	// concatenated together.
	Data []byte `protobuf:"bytes,3,opt,name=data,proto3" json:"data,omitempty"`
	// (Optional) Set this bit to indicate the this is the last data block
	// for the given instruction and transform, ending the stream.
	IsLast bool `protobuf:"varint,4,opt,name=is_last,json=isLast,proto3" json:"is_last,omitempty"`
	// contains filtered or unexported fields
}

Represents multiple encoded elements in nested context for a given named instruction and transform.

func (*Elements_Data) Descriptor deprecated

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

Deprecated: Use Elements_Data.ProtoReflect.Descriptor instead.

func (*Elements_Data) GetData

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

func (*Elements_Data) GetInstructionId

func (x *Elements_Data) GetInstructionId() string

func (*Elements_Data) GetIsLast

func (x *Elements_Data) GetIsLast() bool

func (*Elements_Data) GetTransformId

func (x *Elements_Data) GetTransformId() string

func (*Elements_Data) ProtoMessage

func (*Elements_Data) ProtoMessage()

func (*Elements_Data) ProtoReflect

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

func (*Elements_Data) Reset

func (x *Elements_Data) Reset()

func (*Elements_Data) String

func (x *Elements_Data) String() string

type Elements_Timers

type Elements_Timers struct {

	// (Required) A reference to an active instruction request with the given
	// instruction id.
	InstructionId string `protobuf:"bytes,1,opt,name=instruction_id,json=instructionId,proto3" json:"instruction_id,omitempty"`
	// (Required) A definition representing a consumer or producer of this data.
	// If received by a harness, this represents the consumer within that
	// harness that should consume these timers. If sent by a harness, this
	// represents the producer of these timers.
	TransformId string `protobuf:"bytes,2,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Required) The local timer family name used to identify the associated
	// timer family specification
	TimerFamilyId string `protobuf:"bytes,3,opt,name=timer_family_id,json=timerFamilyId,proto3" json:"timer_family_id,omitempty"`
	// (Optional) Represents a logical byte stream of timers. Encoded according
	// to the coder in the timer spec.
	Timers []byte `protobuf:"bytes,4,opt,name=timers,proto3" json:"timers,omitempty"`
	// (Optional) Set this bit to indicate the this is the last data block
	// for the given instruction and transform, ending the stream.
	IsLast bool `protobuf:"varint,5,opt,name=is_last,json=isLast,proto3" json:"is_last,omitempty"`
	// contains filtered or unexported fields
}

Represent the encoded user timer for a given instruction, transform and timer id.

func (*Elements_Timers) Descriptor deprecated

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

Deprecated: Use Elements_Timers.ProtoReflect.Descriptor instead.

func (*Elements_Timers) GetInstructionId

func (x *Elements_Timers) GetInstructionId() string

func (*Elements_Timers) GetIsLast

func (x *Elements_Timers) GetIsLast() bool

func (*Elements_Timers) GetTimerFamilyId

func (x *Elements_Timers) GetTimerFamilyId() string

func (*Elements_Timers) GetTimers

func (x *Elements_Timers) GetTimers() []byte

func (*Elements_Timers) GetTransformId

func (x *Elements_Timers) GetTransformId() string

func (*Elements_Timers) ProtoMessage

func (*Elements_Timers) ProtoMessage()

func (*Elements_Timers) ProtoReflect

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

func (*Elements_Timers) Reset

func (x *Elements_Timers) Reset()

func (*Elements_Timers) String

func (x *Elements_Timers) String() string

type FinalizeBundleRequest

type FinalizeBundleRequest struct {

	// (Required) A reference to a completed process bundle request with the given
	// instruction id.
	InstructionId string `protobuf:"bytes,1,opt,name=instruction_id,json=instructionId,proto3" json:"instruction_id,omitempty"`
	// contains filtered or unexported fields
}

func (*FinalizeBundleRequest) Descriptor deprecated

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

Deprecated: Use FinalizeBundleRequest.ProtoReflect.Descriptor instead.

func (*FinalizeBundleRequest) GetInstructionId

func (x *FinalizeBundleRequest) GetInstructionId() string

func (*FinalizeBundleRequest) ProtoMessage

func (*FinalizeBundleRequest) ProtoMessage()

func (*FinalizeBundleRequest) ProtoReflect

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

func (*FinalizeBundleRequest) Reset

func (x *FinalizeBundleRequest) Reset()

func (*FinalizeBundleRequest) String

func (x *FinalizeBundleRequest) String() string

type FinalizeBundleResponse

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

func (*FinalizeBundleResponse) Descriptor deprecated

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

Deprecated: Use FinalizeBundleResponse.ProtoReflect.Descriptor instead.

func (*FinalizeBundleResponse) ProtoMessage

func (*FinalizeBundleResponse) ProtoMessage()

func (*FinalizeBundleResponse) ProtoReflect

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

func (*FinalizeBundleResponse) Reset

func (x *FinalizeBundleResponse) Reset()

func (*FinalizeBundleResponse) String

func (x *FinalizeBundleResponse) String() string

type GetProcessBundleDescriptorRequest

type GetProcessBundleDescriptorRequest struct {
	ProcessBundleDescriptorId string `` /* 140-byte string literal not displayed */
	// contains filtered or unexported fields
}

Requests the ProcessBundleDescriptor with the given id.

func (*GetProcessBundleDescriptorRequest) Descriptor deprecated

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

Deprecated: Use GetProcessBundleDescriptorRequest.ProtoReflect.Descriptor instead.

func (*GetProcessBundleDescriptorRequest) GetProcessBundleDescriptorId

func (x *GetProcessBundleDescriptorRequest) GetProcessBundleDescriptorId() string

func (*GetProcessBundleDescriptorRequest) ProtoMessage

func (*GetProcessBundleDescriptorRequest) ProtoMessage()

func (*GetProcessBundleDescriptorRequest) ProtoReflect

func (*GetProcessBundleDescriptorRequest) Reset

func (*GetProcessBundleDescriptorRequest) String

type GetProvisionInfoRequest

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

A request to get the provision info of a SDK harness worker instance.

func (*GetProvisionInfoRequest) Descriptor deprecated

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

Deprecated: Use GetProvisionInfoRequest.ProtoReflect.Descriptor instead.

func (*GetProvisionInfoRequest) ProtoMessage

func (*GetProvisionInfoRequest) ProtoMessage()

func (*GetProvisionInfoRequest) ProtoReflect

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

func (*GetProvisionInfoRequest) Reset

func (x *GetProvisionInfoRequest) Reset()

func (*GetProvisionInfoRequest) String

func (x *GetProvisionInfoRequest) String() string

type GetProvisionInfoResponse

type GetProvisionInfoResponse struct {
	Info *ProvisionInfo `protobuf:"bytes,1,opt,name=info,proto3" json:"info,omitempty"`
	// contains filtered or unexported fields
}

A response containing the provision info of a SDK harness worker instance.

func (*GetProvisionInfoResponse) Descriptor deprecated

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

Deprecated: Use GetProvisionInfoResponse.ProtoReflect.Descriptor instead.

func (*GetProvisionInfoResponse) GetInfo

func (*GetProvisionInfoResponse) ProtoMessage

func (*GetProvisionInfoResponse) ProtoMessage()

func (*GetProvisionInfoResponse) ProtoReflect

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

func (*GetProvisionInfoResponse) Reset

func (x *GetProvisionInfoResponse) Reset()

func (*GetProvisionInfoResponse) String

func (x *GetProvisionInfoResponse) String() string

type HarnessMonitoringInfosRequest

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

A request to provide full MonitoringInfo associated with the entire SDK harness process, not specific to a bundle.

An SDK can report metrics using an identifier that only contains the associated payload. A runner who wants to receive the full metrics information can request all the monitoring metadata via a MonitoringInfosMetadataRequest providing a list of ids as necessary.

The SDK is allowed to reuse the identifiers for the lifetime of the associated control connection as long as the MonitoringInfo could be reconstructed fully by overwriting its payload field with the bytes specified here.

func (*HarnessMonitoringInfosRequest) Descriptor deprecated

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

Deprecated: Use HarnessMonitoringInfosRequest.ProtoReflect.Descriptor instead.

func (*HarnessMonitoringInfosRequest) ProtoMessage

func (*HarnessMonitoringInfosRequest) ProtoMessage()

func (*HarnessMonitoringInfosRequest) ProtoReflect

func (*HarnessMonitoringInfosRequest) Reset

func (x *HarnessMonitoringInfosRequest) Reset()

func (*HarnessMonitoringInfosRequest) String

type HarnessMonitoringInfosResponse

type HarnessMonitoringInfosResponse struct {

	// An identifier to MonitoringInfo.payload mapping containing
	// Metrics associated with the SDK harness, not a specific bundle.
	//
	// An SDK can report metrics using an identifier that only contains the
	// associated payload. A runner who wants to receive the full metrics
	// information can request all the monitoring metadata via a
	// MonitoringInfosMetadataRequest providing a list of ids as necessary.
	//
	// The SDK is allowed to reuse the identifiers
	// for the lifetime of the associated control connection as long
	// as the MonitoringInfo could be reconstructed fully by overwriting its
	// payload field with the bytes specified here.
	MonitoringData map[string][]byte `` /* 191-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*HarnessMonitoringInfosResponse) Descriptor deprecated

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

Deprecated: Use HarnessMonitoringInfosResponse.ProtoReflect.Descriptor instead.

func (*HarnessMonitoringInfosResponse) GetMonitoringData

func (x *HarnessMonitoringInfosResponse) GetMonitoringData() map[string][]byte

func (*HarnessMonitoringInfosResponse) ProtoMessage

func (*HarnessMonitoringInfosResponse) ProtoMessage()

func (*HarnessMonitoringInfosResponse) ProtoReflect

func (*HarnessMonitoringInfosResponse) Reset

func (x *HarnessMonitoringInfosResponse) Reset()

func (*HarnessMonitoringInfosResponse) String

type InstructionRequest

type InstructionRequest struct {

	// (Required) A unique identifier provided by the runner which represents
	// this requests execution. The InstructionResponse MUST have the matching id.
	InstructionId string `protobuf:"bytes,1,opt,name=instruction_id,json=instructionId,proto3" json:"instruction_id,omitempty"`
	// (Required) A request that the SDK Harness needs to interpret.
	//
	// Types that are assignable to Request:
	//	*InstructionRequest_ProcessBundle
	//	*InstructionRequest_ProcessBundleProgress
	//	*InstructionRequest_ProcessBundleSplit
	//	*InstructionRequest_FinalizeBundle
	//	*InstructionRequest_MonitoringInfos
	//	*InstructionRequest_HarnessMonitoringInfos
	//	*InstructionRequest_Register
	Request isInstructionRequest_Request `protobuf_oneof:"request"`
	// contains filtered or unexported fields
}

A request sent by a runner which the SDK is asked to fulfill. For any unsupported request type, an error should be returned with a matching instruction id. Stable

func (*InstructionRequest) Descriptor deprecated

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

Deprecated: Use InstructionRequest.ProtoReflect.Descriptor instead.

func (*InstructionRequest) GetFinalizeBundle

func (x *InstructionRequest) GetFinalizeBundle() *FinalizeBundleRequest

func (*InstructionRequest) GetHarnessMonitoringInfos

func (x *InstructionRequest) GetHarnessMonitoringInfos() *HarnessMonitoringInfosRequest

func (*InstructionRequest) GetInstructionId

func (x *InstructionRequest) GetInstructionId() string

func (*InstructionRequest) GetMonitoringInfos

func (x *InstructionRequest) GetMonitoringInfos() *MonitoringInfosMetadataRequest

func (*InstructionRequest) GetProcessBundle

func (x *InstructionRequest) GetProcessBundle() *ProcessBundleRequest

func (*InstructionRequest) GetProcessBundleProgress

func (x *InstructionRequest) GetProcessBundleProgress() *ProcessBundleProgressRequest

func (*InstructionRequest) GetProcessBundleSplit

func (x *InstructionRequest) GetProcessBundleSplit() *ProcessBundleSplitRequest

func (*InstructionRequest) GetRegister

func (x *InstructionRequest) GetRegister() *RegisterRequest

func (*InstructionRequest) GetRequest

func (m *InstructionRequest) GetRequest() isInstructionRequest_Request

func (*InstructionRequest) ProtoMessage

func (*InstructionRequest) ProtoMessage()

func (*InstructionRequest) ProtoReflect

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

func (*InstructionRequest) Reset

func (x *InstructionRequest) Reset()

func (*InstructionRequest) String

func (x *InstructionRequest) String() string

type InstructionRequest_FinalizeBundle

type InstructionRequest_FinalizeBundle struct {
	FinalizeBundle *FinalizeBundleRequest `protobuf:"bytes,1004,opt,name=finalize_bundle,json=finalizeBundle,proto3,oneof"`
}

type InstructionRequest_HarnessMonitoringInfos

type InstructionRequest_HarnessMonitoringInfos struct {
	HarnessMonitoringInfos *HarnessMonitoringInfosRequest `protobuf:"bytes,1006,opt,name=harness_monitoring_infos,json=harnessMonitoringInfos,proto3,oneof"`
}

type InstructionRequest_MonitoringInfos

type InstructionRequest_MonitoringInfos struct {
	MonitoringInfos *MonitoringInfosMetadataRequest `protobuf:"bytes,1005,opt,name=monitoring_infos,json=monitoringInfos,proto3,oneof"`
}

type InstructionRequest_ProcessBundle

type InstructionRequest_ProcessBundle struct {
	ProcessBundle *ProcessBundleRequest `protobuf:"bytes,1001,opt,name=process_bundle,json=processBundle,proto3,oneof"`
}

type InstructionRequest_ProcessBundleProgress

type InstructionRequest_ProcessBundleProgress struct {
	ProcessBundleProgress *ProcessBundleProgressRequest `protobuf:"bytes,1002,opt,name=process_bundle_progress,json=processBundleProgress,proto3,oneof"`
}

type InstructionRequest_ProcessBundleSplit

type InstructionRequest_ProcessBundleSplit struct {
	ProcessBundleSplit *ProcessBundleSplitRequest `protobuf:"bytes,1003,opt,name=process_bundle_split,json=processBundleSplit,proto3,oneof"`
}

type InstructionRequest_Register

type InstructionRequest_Register struct {
	// DEPRECATED
	Register *RegisterRequest `protobuf:"bytes,1000,opt,name=register,proto3,oneof"`
}

type InstructionResponse

type InstructionResponse struct {

	// (Required) A reference provided by the runner which represents a requests
	// execution. The InstructionResponse MUST have the matching id when
	// responding to the runner.
	InstructionId string `protobuf:"bytes,1,opt,name=instruction_id,json=instructionId,proto3" json:"instruction_id,omitempty"`
	// If this is specified, then this instruction has failed.
	// A human readable string representing the reason as to why processing has
	// failed.
	Error string `protobuf:"bytes,2,opt,name=error,proto3" json:"error,omitempty"`
	// If the instruction did not fail, it is required to return an equivalent
	// response type depending on the request this matches.
	//
	// Types that are assignable to Response:
	//	*InstructionResponse_ProcessBundle
	//	*InstructionResponse_ProcessBundleProgress
	//	*InstructionResponse_ProcessBundleSplit
	//	*InstructionResponse_FinalizeBundle
	//	*InstructionResponse_MonitoringInfos
	//	*InstructionResponse_HarnessMonitoringInfos
	//	*InstructionResponse_Register
	Response isInstructionResponse_Response `protobuf_oneof:"response"`
	// contains filtered or unexported fields
}

The response for an associated request the SDK had been asked to fulfill. Stable

func (*InstructionResponse) Descriptor deprecated

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

Deprecated: Use InstructionResponse.ProtoReflect.Descriptor instead.

func (*InstructionResponse) GetError

func (x *InstructionResponse) GetError() string

func (*InstructionResponse) GetFinalizeBundle

func (x *InstructionResponse) GetFinalizeBundle() *FinalizeBundleResponse

func (*InstructionResponse) GetHarnessMonitoringInfos

func (x *InstructionResponse) GetHarnessMonitoringInfos() *HarnessMonitoringInfosResponse

func (*InstructionResponse) GetInstructionId

func (x *InstructionResponse) GetInstructionId() string

func (*InstructionResponse) GetMonitoringInfos

func (x *InstructionResponse) GetMonitoringInfos() *MonitoringInfosMetadataResponse

func (*InstructionResponse) GetProcessBundle

func (x *InstructionResponse) GetProcessBundle() *ProcessBundleResponse

func (*InstructionResponse) GetProcessBundleProgress

func (x *InstructionResponse) GetProcessBundleProgress() *ProcessBundleProgressResponse

func (*InstructionResponse) GetProcessBundleSplit

func (x *InstructionResponse) GetProcessBundleSplit() *ProcessBundleSplitResponse

func (*InstructionResponse) GetRegister

func (x *InstructionResponse) GetRegister() *RegisterResponse

func (*InstructionResponse) GetResponse

func (m *InstructionResponse) GetResponse() isInstructionResponse_Response

func (*InstructionResponse) ProtoMessage

func (*InstructionResponse) ProtoMessage()

func (*InstructionResponse) ProtoReflect

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

func (*InstructionResponse) Reset

func (x *InstructionResponse) Reset()

func (*InstructionResponse) String

func (x *InstructionResponse) String() string

type InstructionResponse_FinalizeBundle

type InstructionResponse_FinalizeBundle struct {
	FinalizeBundle *FinalizeBundleResponse `protobuf:"bytes,1004,opt,name=finalize_bundle,json=finalizeBundle,proto3,oneof"`
}

type InstructionResponse_HarnessMonitoringInfos

type InstructionResponse_HarnessMonitoringInfos struct {
	HarnessMonitoringInfos *HarnessMonitoringInfosResponse `protobuf:"bytes,1006,opt,name=harness_monitoring_infos,json=harnessMonitoringInfos,proto3,oneof"`
}

type InstructionResponse_MonitoringInfos

type InstructionResponse_MonitoringInfos struct {
	MonitoringInfos *MonitoringInfosMetadataResponse `protobuf:"bytes,1005,opt,name=monitoring_infos,json=monitoringInfos,proto3,oneof"`
}

type InstructionResponse_ProcessBundle

type InstructionResponse_ProcessBundle struct {
	ProcessBundle *ProcessBundleResponse `protobuf:"bytes,1001,opt,name=process_bundle,json=processBundle,proto3,oneof"`
}

type InstructionResponse_ProcessBundleProgress

type InstructionResponse_ProcessBundleProgress struct {
	ProcessBundleProgress *ProcessBundleProgressResponse `protobuf:"bytes,1002,opt,name=process_bundle_progress,json=processBundleProgress,proto3,oneof"`
}

type InstructionResponse_ProcessBundleSplit

type InstructionResponse_ProcessBundleSplit struct {
	ProcessBundleSplit *ProcessBundleSplitResponse `protobuf:"bytes,1003,opt,name=process_bundle_split,json=processBundleSplit,proto3,oneof"`
}

type InstructionResponse_Register

type InstructionResponse_Register struct {
	// DEPRECATED
	Register *RegisterResponse `protobuf:"bytes,1000,opt,name=register,proto3,oneof"`
}

type LogControl

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

func (*LogControl) Descriptor deprecated

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

Deprecated: Use LogControl.ProtoReflect.Descriptor instead.

func (*LogControl) ProtoMessage

func (*LogControl) ProtoMessage()

func (*LogControl) ProtoReflect

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

func (*LogControl) Reset

func (x *LogControl) Reset()

func (*LogControl) String

func (x *LogControl) String() string

type LogEntry

type LogEntry struct {

	// (Required) The severity of the log statement.
	Severity LogEntry_Severity_Enum `` /* 136-byte string literal not displayed */
	// (Required) The time at which this log statement occurred.
	Timestamp *timestamp.Timestamp `protobuf:"bytes,2,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	// (Required) A human readable message.
	Message string `protobuf:"bytes,3,opt,name=message,proto3" json:"message,omitempty"`
	// (Optional) An optional trace of the functions involved. For example, in
	// Java this can include multiple causes and multiple suppressed exceptions.
	Trace string `protobuf:"bytes,4,opt,name=trace,proto3" json:"trace,omitempty"`
	// (Optional) A reference to the instruction this log statement is associated
	// with.
	InstructionId string `protobuf:"bytes,5,opt,name=instruction_id,json=instructionId,proto3" json:"instruction_id,omitempty"`
	// (Optional) A reference to the transform this log statement is
	// associated with.
	TransformId string `protobuf:"bytes,6,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Optional) Human-readable name of the function or method being invoked,
	// with optional context such as the class or package name. The format can
	// vary by language. For example:
	//   qual.if.ied.Class.method (Java)
	//   dir/package.func (Go)
	//   module.function (Python)
	//   file.cc:382 (C++)
	LogLocation string `protobuf:"bytes,7,opt,name=log_location,json=logLocation,proto3" json:"log_location,omitempty"`
	// (Optional) The name of the thread this log statement is associated with.
	Thread string `protobuf:"bytes,8,opt,name=thread,proto3" json:"thread,omitempty"`
	// contains filtered or unexported fields
}

A log entry

func (*LogEntry) Descriptor deprecated

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

Deprecated: Use LogEntry.ProtoReflect.Descriptor instead.

func (*LogEntry) GetInstructionId

func (x *LogEntry) GetInstructionId() string

func (*LogEntry) GetLogLocation

func (x *LogEntry) GetLogLocation() string

func (*LogEntry) GetMessage

func (x *LogEntry) GetMessage() string

func (*LogEntry) GetSeverity

func (x *LogEntry) GetSeverity() LogEntry_Severity_Enum

func (*LogEntry) GetThread

func (x *LogEntry) GetThread() string

func (*LogEntry) GetTimestamp

func (x *LogEntry) GetTimestamp() *timestamp.Timestamp

func (*LogEntry) GetTrace

func (x *LogEntry) GetTrace() string

func (*LogEntry) GetTransformId

func (x *LogEntry) GetTransformId() string

func (*LogEntry) ProtoMessage

func (*LogEntry) ProtoMessage()

func (*LogEntry) ProtoReflect

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

func (*LogEntry) Reset

func (x *LogEntry) Reset()

func (*LogEntry) String

func (x *LogEntry) String() string

type LogEntry_List

type LogEntry_List struct {

	// (Required) One or or more log messages.
	LogEntries []*LogEntry `protobuf:"bytes,1,rep,name=log_entries,json=logEntries,proto3" json:"log_entries,omitempty"`
	// contains filtered or unexported fields
}

A list of log entries, enables buffering and batching of multiple log messages using the logging API.

func (*LogEntry_List) Descriptor deprecated

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

Deprecated: Use LogEntry_List.ProtoReflect.Descriptor instead.

func (*LogEntry_List) GetLogEntries

func (x *LogEntry_List) GetLogEntries() []*LogEntry

func (*LogEntry_List) ProtoMessage

func (*LogEntry_List) ProtoMessage()

func (*LogEntry_List) ProtoReflect

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

func (*LogEntry_List) Reset

func (x *LogEntry_List) Reset()

func (*LogEntry_List) String

func (x *LogEntry_List) String() string

type LogEntry_Severity

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

The severity of the event described in a log entry, expressed as one of the severity levels listed below. For your reference, the levels are assigned the listed numeric values. The effect of using numeric values other than those listed is undefined.

If you are writing log entries, you should map other severity encodings to one of these standard levels. For example, you might map all of Java's FINE, FINER, and FINEST levels to `Severity.DEBUG`.

This list is intentionally not comprehensive; the intent is to provide a common set of "good enough" severity levels so that logging front ends can provide filtering and searching across log types. Users of the API are free not to use all severity levels in their log messages.

func (*LogEntry_Severity) Descriptor deprecated

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

Deprecated: Use LogEntry_Severity.ProtoReflect.Descriptor instead.

func (*LogEntry_Severity) ProtoMessage

func (*LogEntry_Severity) ProtoMessage()

func (*LogEntry_Severity) ProtoReflect

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

func (*LogEntry_Severity) Reset

func (x *LogEntry_Severity) Reset()

func (*LogEntry_Severity) String

func (x *LogEntry_Severity) String() string

type LogEntry_Severity_Enum

type LogEntry_Severity_Enum int32
const (
	// Unspecified level information. Will be logged at the TRACE level.
	LogEntry_Severity_UNSPECIFIED LogEntry_Severity_Enum = 0
	LogEntry_Severity_TRACE       LogEntry_Severity_Enum = 1
	// Debugging information.
	LogEntry_Severity_DEBUG LogEntry_Severity_Enum = 2
	// Normal events.
	LogEntry_Severity_INFO LogEntry_Severity_Enum = 3
	// Normal but significant events, such as start up, shut down, or
	// configuration.
	LogEntry_Severity_NOTICE LogEntry_Severity_Enum = 4
	// Warning events might cause problems.
	LogEntry_Severity_WARN LogEntry_Severity_Enum = 5
	// Error events are likely to cause problems.
	LogEntry_Severity_ERROR LogEntry_Severity_Enum = 6
	// Critical events cause severe problems or brief outages and may
	// indicate that a person must take action.
	LogEntry_Severity_CRITICAL LogEntry_Severity_Enum = 7
)

func (LogEntry_Severity_Enum) Descriptor

func (LogEntry_Severity_Enum) Enum

func (LogEntry_Severity_Enum) EnumDescriptor deprecated

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

Deprecated: Use LogEntry_Severity_Enum.Descriptor instead.

func (LogEntry_Severity_Enum) Number

func (LogEntry_Severity_Enum) String

func (x LogEntry_Severity_Enum) String() string

func (LogEntry_Severity_Enum) Type

type MonitoringInfosMetadataRequest

type MonitoringInfosMetadataRequest struct {

	// A list of ids for which the full MonitoringInfo is requested for.
	MonitoringInfoId []string `protobuf:"bytes,1,rep,name=monitoring_info_id,json=monitoringInfoId,proto3" json:"monitoring_info_id,omitempty"`
	// contains filtered or unexported fields
}

A request to provide full MonitoringInfo for a set of provided ids.

An SDK can report metrics using an identifier that only contains the associated payload. A runner who wants to receive the full metrics information can request all the monitoring metadata via a MonitoringInfosMetadataRequest providing a list of ids as necessary.

The SDK is allowed to reuse the identifiers for the lifetime of the associated control connection as long as the MonitoringInfo could be reconstructed fully by overwriting its payload field with the bytes specified here.

func (*MonitoringInfosMetadataRequest) Descriptor deprecated

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

Deprecated: Use MonitoringInfosMetadataRequest.ProtoReflect.Descriptor instead.

func (*MonitoringInfosMetadataRequest) GetMonitoringInfoId

func (x *MonitoringInfosMetadataRequest) GetMonitoringInfoId() []string

func (*MonitoringInfosMetadataRequest) ProtoMessage

func (*MonitoringInfosMetadataRequest) ProtoMessage()

func (*MonitoringInfosMetadataRequest) ProtoReflect

func (*MonitoringInfosMetadataRequest) Reset

func (x *MonitoringInfosMetadataRequest) Reset()

func (*MonitoringInfosMetadataRequest) String

type MonitoringInfosMetadataResponse

type MonitoringInfosMetadataResponse struct {

	// A mapping from an identifier to the full metrics information.
	MonitoringInfo map[string]*pipeline_v1.MonitoringInfo `` /* 191-byte string literal not displayed */
	// contains filtered or unexported fields
}

A response that contains the full mapping information associated with a specified set of identifiers.

An SDK can report metrics using an identifier that only contains the associated payload. A runner who wants to receive the full metrics information can request all the monitoring metadata via a MonitoringInfosMetadataRequest providing a list of ids as necessary.

The SDK is allowed to reuse the identifiers for the lifetime of the associated control connection as long as the MonitoringInfo could be reconstructed fully by overwriting its payload field with the bytes specified here.

func (*MonitoringInfosMetadataResponse) Descriptor deprecated

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

Deprecated: Use MonitoringInfosMetadataResponse.ProtoReflect.Descriptor instead.

func (*MonitoringInfosMetadataResponse) GetMonitoringInfo

func (*MonitoringInfosMetadataResponse) ProtoMessage

func (*MonitoringInfosMetadataResponse) ProtoMessage()

func (*MonitoringInfosMetadataResponse) ProtoReflect

func (*MonitoringInfosMetadataResponse) Reset

func (*MonitoringInfosMetadataResponse) String

type ProcessBundleDescriptor

type ProcessBundleDescriptor struct {

	// (Required) A pipeline level unique id which can be used as a reference to
	// refer to this.
	Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	// (Required) A map from pipeline-scoped id to PTransform.
	Transforms map[string]*pipeline_v1.PTransform `` /* 161-byte string literal not displayed */
	// (Required) A map from pipeline-scoped id to PCollection.
	Pcollections map[string]*pipeline_v1.PCollection `` /* 165-byte string literal not displayed */
	// (Required) A map from pipeline-scoped id to WindowingStrategy.
	WindowingStrategies map[string]*pipeline_v1.WindowingStrategy `` /* 206-byte string literal not displayed */
	// (Required) A map from pipeline-scoped id to Coder.
	Coders map[string]*pipeline_v1.Coder `` /* 153-byte string literal not displayed */
	// (Required) A map from pipeline-scoped id to Environment.
	Environments map[string]*pipeline_v1.Environment `` /* 165-byte string literal not displayed */
	// A descriptor describing the end point to use for State API
	// calls. Required if the Runner intends to send remote references over the
	// data plane or if any of the transforms rely on user state or side inputs.
	StateApiServiceDescriptor *pipeline_v1.ApiServiceDescriptor `` /* 140-byte string literal not displayed */
	// A descriptor describing the end point to use for Data API for user timers.
	// Required if the ProcessBundleDescriptor contains any transforms that have user timers.
	TimerApiServiceDescriptor *pipeline_v1.ApiServiceDescriptor `` /* 140-byte string literal not displayed */
	// contains filtered or unexported fields
}

Definitions that should be used to construct the bundle processing graph.

func (*ProcessBundleDescriptor) Descriptor deprecated

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

Deprecated: Use ProcessBundleDescriptor.ProtoReflect.Descriptor instead.

func (*ProcessBundleDescriptor) GetCoders

func (x *ProcessBundleDescriptor) GetCoders() map[string]*pipeline_v1.Coder

func (*ProcessBundleDescriptor) GetEnvironments

func (x *ProcessBundleDescriptor) GetEnvironments() map[string]*pipeline_v1.Environment

func (*ProcessBundleDescriptor) GetId

func (x *ProcessBundleDescriptor) GetId() string

func (*ProcessBundleDescriptor) GetPcollections

func (x *ProcessBundleDescriptor) GetPcollections() map[string]*pipeline_v1.PCollection

func (*ProcessBundleDescriptor) GetStateApiServiceDescriptor

func (x *ProcessBundleDescriptor) GetStateApiServiceDescriptor() *pipeline_v1.ApiServiceDescriptor

func (*ProcessBundleDescriptor) GetTimerApiServiceDescriptor

func (x *ProcessBundleDescriptor) GetTimerApiServiceDescriptor() *pipeline_v1.ApiServiceDescriptor

func (*ProcessBundleDescriptor) GetTransforms

func (x *ProcessBundleDescriptor) GetTransforms() map[string]*pipeline_v1.PTransform

func (*ProcessBundleDescriptor) GetWindowingStrategies

func (x *ProcessBundleDescriptor) GetWindowingStrategies() map[string]*pipeline_v1.WindowingStrategy

func (*ProcessBundleDescriptor) ProtoMessage

func (*ProcessBundleDescriptor) ProtoMessage()

func (*ProcessBundleDescriptor) ProtoReflect

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

func (*ProcessBundleDescriptor) Reset

func (x *ProcessBundleDescriptor) Reset()

func (*ProcessBundleDescriptor) String

func (x *ProcessBundleDescriptor) String() string

type ProcessBundleProgressRequest

type ProcessBundleProgressRequest struct {

	// (Required) A reference to an active process bundle request with the given
	// instruction id.
	InstructionId string `protobuf:"bytes,1,opt,name=instruction_id,json=instructionId,proto3" json:"instruction_id,omitempty"`
	// contains filtered or unexported fields
}

A request to report progress information for a given bundle. This is an optional request to be handled and is used to support advanced SDK features such as SplittableDoFn, user level metrics etc.

func (*ProcessBundleProgressRequest) Descriptor deprecated

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

Deprecated: Use ProcessBundleProgressRequest.ProtoReflect.Descriptor instead.

func (*ProcessBundleProgressRequest) GetInstructionId

func (x *ProcessBundleProgressRequest) GetInstructionId() string

func (*ProcessBundleProgressRequest) ProtoMessage

func (*ProcessBundleProgressRequest) ProtoMessage()

func (*ProcessBundleProgressRequest) ProtoReflect

func (*ProcessBundleProgressRequest) Reset

func (x *ProcessBundleProgressRequest) Reset()

func (*ProcessBundleProgressRequest) String

type ProcessBundleProgressResponse

type ProcessBundleProgressResponse struct {

	// DEPRECATED (Required) The list of metrics or other MonitoredState
	// collected while processing this bundle.
	MonitoringInfos []*pipeline_v1.MonitoringInfo `protobuf:"bytes,3,rep,name=monitoring_infos,json=monitoringInfos,proto3" json:"monitoring_infos,omitempty"`
	// An identifier to MonitoringInfo.payload mapping.
	//
	// An SDK can report metrics using an identifier that only contains the
	// associated payload. A runner who wants to receive the full metrics
	// information can request all the monitoring metadata via a
	// MonitoringInfosMetadataRequest providing a list of ids as necessary.
	//
	// The SDK is allowed to reuse the identifiers
	// for the lifetime of the associated control connection as long
	// as the MonitoringInfo could be reconstructed fully by overwriting its
	// payload field with the bytes specified here.
	MonitoringData map[string][]byte `` /* 191-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*ProcessBundleProgressResponse) Descriptor deprecated

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

Deprecated: Use ProcessBundleProgressResponse.ProtoReflect.Descriptor instead.

func (*ProcessBundleProgressResponse) GetMonitoringData

func (x *ProcessBundleProgressResponse) GetMonitoringData() map[string][]byte

func (*ProcessBundleProgressResponse) GetMonitoringInfos

func (x *ProcessBundleProgressResponse) GetMonitoringInfos() []*pipeline_v1.MonitoringInfo

func (*ProcessBundleProgressResponse) ProtoMessage

func (*ProcessBundleProgressResponse) ProtoMessage()

func (*ProcessBundleProgressResponse) ProtoReflect

func (*ProcessBundleProgressResponse) Reset

func (x *ProcessBundleProgressResponse) Reset()

func (*ProcessBundleProgressResponse) String

type ProcessBundleRequest

type ProcessBundleRequest struct {

	// (Required) A reference to the process bundle descriptor that must be
	// instantiated and executed by the SDK harness.
	ProcessBundleDescriptorId string `` /* 140-byte string literal not displayed */
	// (Optional) A list of cache tokens that can be used by an SDK to reuse
	// cached data returned by the State API across multiple bundles.
	CacheTokens []*ProcessBundleRequest_CacheToken `protobuf:"bytes,2,rep,name=cache_tokens,json=cacheTokens,proto3" json:"cache_tokens,omitempty"`
	// contains filtered or unexported fields
}

A request to process a given bundle. Stable

func (*ProcessBundleRequest) Descriptor deprecated

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

Deprecated: Use ProcessBundleRequest.ProtoReflect.Descriptor instead.

func (*ProcessBundleRequest) GetCacheTokens

func (*ProcessBundleRequest) GetProcessBundleDescriptorId

func (x *ProcessBundleRequest) GetProcessBundleDescriptorId() string

func (*ProcessBundleRequest) ProtoMessage

func (*ProcessBundleRequest) ProtoMessage()

func (*ProcessBundleRequest) ProtoReflect

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

func (*ProcessBundleRequest) Reset

func (x *ProcessBundleRequest) Reset()

func (*ProcessBundleRequest) String

func (x *ProcessBundleRequest) String() string

type ProcessBundleRequest_CacheToken

type ProcessBundleRequest_CacheToken struct {

	// The scope of a cache token.
	//
	// Types that are assignable to Type:
	//	*ProcessBundleRequest_CacheToken_UserState_
	//	*ProcessBundleRequest_CacheToken_SideInput_
	Type isProcessBundleRequest_CacheToken_Type `protobuf_oneof:"type"`
	// The cache token identifier which should be globally unique.
	Token []byte `protobuf:"bytes,10,opt,name=token,proto3" json:"token,omitempty"`
	// contains filtered or unexported fields
}

A cache token which can be used by an SDK to check for the validity of cached elements which have a cache token associated.

func (*ProcessBundleRequest_CacheToken) Descriptor deprecated

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

Deprecated: Use ProcessBundleRequest_CacheToken.ProtoReflect.Descriptor instead.

func (*ProcessBundleRequest_CacheToken) GetSideInput

func (*ProcessBundleRequest_CacheToken) GetToken

func (x *ProcessBundleRequest_CacheToken) GetToken() []byte

func (*ProcessBundleRequest_CacheToken) GetType

func (m *ProcessBundleRequest_CacheToken) GetType() isProcessBundleRequest_CacheToken_Type

func (*ProcessBundleRequest_CacheToken) GetUserState

func (*ProcessBundleRequest_CacheToken) ProtoMessage

func (*ProcessBundleRequest_CacheToken) ProtoMessage()

func (*ProcessBundleRequest_CacheToken) ProtoReflect

func (*ProcessBundleRequest_CacheToken) Reset

func (*ProcessBundleRequest_CacheToken) String

type ProcessBundleRequest_CacheToken_SideInput

type ProcessBundleRequest_CacheToken_SideInput struct {

	// (Required) The id of the PTransform containing a side input.
	TransformId string `protobuf:"bytes,1,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Required) The id of the side input.
	SideInputId string `protobuf:"bytes,2,opt,name=side_input_id,json=sideInputId,proto3" json:"side_input_id,omitempty"`
	// contains filtered or unexported fields
}

A flag to indicate a cache token is valid for a side input.

func (*ProcessBundleRequest_CacheToken_SideInput) Descriptor deprecated

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

Deprecated: Use ProcessBundleRequest_CacheToken_SideInput.ProtoReflect.Descriptor instead.

func (*ProcessBundleRequest_CacheToken_SideInput) GetSideInputId

func (*ProcessBundleRequest_CacheToken_SideInput) GetTransformId

func (*ProcessBundleRequest_CacheToken_SideInput) ProtoMessage

func (*ProcessBundleRequest_CacheToken_SideInput) ProtoReflect

func (*ProcessBundleRequest_CacheToken_SideInput) Reset

func (*ProcessBundleRequest_CacheToken_SideInput) String

type ProcessBundleRequest_CacheToken_SideInput_

type ProcessBundleRequest_CacheToken_SideInput_ struct {
	SideInput *ProcessBundleRequest_CacheToken_SideInput `protobuf:"bytes,2,opt,name=side_input,json=sideInput,proto3,oneof"`
}

type ProcessBundleRequest_CacheToken_UserState

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

A flag to indicate a cache token is valid for all user state.

func (*ProcessBundleRequest_CacheToken_UserState) Descriptor deprecated

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

Deprecated: Use ProcessBundleRequest_CacheToken_UserState.ProtoReflect.Descriptor instead.

func (*ProcessBundleRequest_CacheToken_UserState) ProtoMessage

func (*ProcessBundleRequest_CacheToken_UserState) ProtoReflect

func (*ProcessBundleRequest_CacheToken_UserState) Reset

func (*ProcessBundleRequest_CacheToken_UserState) String

type ProcessBundleRequest_CacheToken_UserState_

type ProcessBundleRequest_CacheToken_UserState_ struct {
	UserState *ProcessBundleRequest_CacheToken_UserState `protobuf:"bytes,1,opt,name=user_state,json=userState,proto3,oneof"`
}

type ProcessBundleResponse

type ProcessBundleResponse struct {

	// (Optional) Specifies that the bundle has not been completed and the
	// following applications need to be scheduled and executed in the future.
	// A runner that does not yet support residual roots MUST still check that
	// this is empty for correctness.
	ResidualRoots []*DelayedBundleApplication `protobuf:"bytes,2,rep,name=residual_roots,json=residualRoots,proto3" json:"residual_roots,omitempty"`
	// DEPRECATED (Required) The list of metrics or other MonitoredState
	// collected while processing this bundle.
	MonitoringInfos []*pipeline_v1.MonitoringInfo `protobuf:"bytes,3,rep,name=monitoring_infos,json=monitoringInfos,proto3" json:"monitoring_infos,omitempty"`
	// (Optional) Specifies that the runner must callback to this worker
	// once the output of the bundle is committed. The Runner must send a
	// FinalizeBundleRequest with the instruction id of the ProcessBundleRequest
	// that is related to this ProcessBundleResponse.
	RequiresFinalization bool `protobuf:"varint,4,opt,name=requires_finalization,json=requiresFinalization,proto3" json:"requires_finalization,omitempty"`
	// An identifier to MonitoringInfo.payload mapping.
	//
	// An SDK can report metrics using an identifier that only contains the
	// associated payload. A runner who wants to receive the full metrics
	// information can request all the monitoring metadata via a
	// MonitoringInfosMetadataRequest providing a list of ids as necessary.
	//
	// The SDK is allowed to reuse the identifiers across multiple bundles as long
	// as the MonitoringInfo could be reconstructed fully by overwriting its
	// payload field with the bytes specified here.
	MonitoringData map[string][]byte `` /* 191-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*ProcessBundleResponse) Descriptor deprecated

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

Deprecated: Use ProcessBundleResponse.ProtoReflect.Descriptor instead.

func (*ProcessBundleResponse) GetMonitoringData

func (x *ProcessBundleResponse) GetMonitoringData() map[string][]byte

func (*ProcessBundleResponse) GetMonitoringInfos

func (x *ProcessBundleResponse) GetMonitoringInfos() []*pipeline_v1.MonitoringInfo

func (*ProcessBundleResponse) GetRequiresFinalization

func (x *ProcessBundleResponse) GetRequiresFinalization() bool

func (*ProcessBundleResponse) GetResidualRoots

func (x *ProcessBundleResponse) GetResidualRoots() []*DelayedBundleApplication

func (*ProcessBundleResponse) ProtoMessage

func (*ProcessBundleResponse) ProtoMessage()

func (*ProcessBundleResponse) ProtoReflect

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

func (*ProcessBundleResponse) Reset

func (x *ProcessBundleResponse) Reset()

func (*ProcessBundleResponse) String

func (x *ProcessBundleResponse) String() string

type ProcessBundleSplitRequest

type ProcessBundleSplitRequest struct {

	// (Required) A reference to an active process bundle request with the given
	// instruction id.
	InstructionId string `protobuf:"bytes,1,opt,name=instruction_id,json=instructionId,proto3" json:"instruction_id,omitempty"`
	// (Required) Specifies the desired split for each transform.
	//
	// Currently only splits at GRPC read operations are supported.
	// This may, of course, limit the amount of work downstream operations
	// receive.
	DesiredSplits map[string]*ProcessBundleSplitRequest_DesiredSplit `` /* 188-byte string literal not displayed */
	// contains filtered or unexported fields
}

Represents a request to the SDK to split a currently active bundle.

func (*ProcessBundleSplitRequest) Descriptor deprecated

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

Deprecated: Use ProcessBundleSplitRequest.ProtoReflect.Descriptor instead.

func (*ProcessBundleSplitRequest) GetDesiredSplits

func (*ProcessBundleSplitRequest) GetInstructionId

func (x *ProcessBundleSplitRequest) GetInstructionId() string

func (*ProcessBundleSplitRequest) ProtoMessage

func (*ProcessBundleSplitRequest) ProtoMessage()

func (*ProcessBundleSplitRequest) ProtoReflect

func (*ProcessBundleSplitRequest) Reset

func (x *ProcessBundleSplitRequest) Reset()

func (*ProcessBundleSplitRequest) String

func (x *ProcessBundleSplitRequest) String() string

type ProcessBundleSplitRequest_DesiredSplit

type ProcessBundleSplitRequest_DesiredSplit struct {

	// (Required) The fraction of known work remaining in this bundle
	// for this transform that should be kept by the SDK after this split.
	//
	// Set to 0 to "checkpoint" as soon as possible (keeping as little work as
	// possible and returning the remainder).
	FractionOfRemainder float64 `protobuf:"fixed64,1,opt,name=fraction_of_remainder,json=fractionOfRemainder,proto3" json:"fraction_of_remainder,omitempty"`
	// A set of allowed element indices where the SDK may split. When this is
	// empty, there are no constraints on where to split.
	AllowedSplitPoints []int64 `protobuf:"varint,3,rep,packed,name=allowed_split_points,json=allowedSplitPoints,proto3" json:"allowed_split_points,omitempty"`
	// (Required for GrpcRead operations) Number of total elements expected
	// to be sent to this GrpcRead operation, required to correctly account
	// for unreceived data when determining where to split.
	EstimatedInputElements int64 `` /* 130-byte string literal not displayed */
	// contains filtered or unexported fields
}

A message specifying the desired split for a single transform.

func (*ProcessBundleSplitRequest_DesiredSplit) Descriptor deprecated

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

Deprecated: Use ProcessBundleSplitRequest_DesiredSplit.ProtoReflect.Descriptor instead.

func (*ProcessBundleSplitRequest_DesiredSplit) GetAllowedSplitPoints

func (x *ProcessBundleSplitRequest_DesiredSplit) GetAllowedSplitPoints() []int64

func (*ProcessBundleSplitRequest_DesiredSplit) GetEstimatedInputElements

func (x *ProcessBundleSplitRequest_DesiredSplit) GetEstimatedInputElements() int64

func (*ProcessBundleSplitRequest_DesiredSplit) GetFractionOfRemainder

func (x *ProcessBundleSplitRequest_DesiredSplit) GetFractionOfRemainder() float64

func (*ProcessBundleSplitRequest_DesiredSplit) ProtoMessage

func (*ProcessBundleSplitRequest_DesiredSplit) ProtoReflect

func (*ProcessBundleSplitRequest_DesiredSplit) Reset

func (*ProcessBundleSplitRequest_DesiredSplit) String

type ProcessBundleSplitResponse

type ProcessBundleSplitResponse struct {

	// Root applications that should replace the current bundle.
	PrimaryRoots []*BundleApplication `protobuf:"bytes,1,rep,name=primary_roots,json=primaryRoots,proto3" json:"primary_roots,omitempty"`
	// Root applications that have been removed from the current bundle and
	// have to be executed in a separate bundle (e.g. in parallel on a different
	// worker, or after the current bundle completes, etc.)
	ResidualRoots []*DelayedBundleApplication `protobuf:"bytes,2,rep,name=residual_roots,json=residualRoots,proto3" json:"residual_roots,omitempty"`
	// Partitions of input data channels into primary and residual elements,
	// if any. Should not include any elements represented in the bundle
	// applications roots above.
	ChannelSplits []*ProcessBundleSplitResponse_ChannelSplit `protobuf:"bytes,3,rep,name=channel_splits,json=channelSplits,proto3" json:"channel_splits,omitempty"`
	// contains filtered or unexported fields
}

Represents a partition of the bundle: a "primary" and a "residual", with the following properties:

  • The work in primary and residual doesn't overlap, and combined, adds up to the work in the current bundle if the split hadn't happened.
  • The current bundle, if it keeps executing, will have done none of the work under residual_roots.
  • The current bundle, if no further splits happen, will have done exactly the work under primary_roots.

For more rigorous definitions see https://s.apache.org/beam-breaking-fusion

func (*ProcessBundleSplitResponse) Descriptor deprecated

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

Deprecated: Use ProcessBundleSplitResponse.ProtoReflect.Descriptor instead.

func (*ProcessBundleSplitResponse) GetChannelSplits

func (*ProcessBundleSplitResponse) GetPrimaryRoots

func (x *ProcessBundleSplitResponse) GetPrimaryRoots() []*BundleApplication

func (*ProcessBundleSplitResponse) GetResidualRoots

func (x *ProcessBundleSplitResponse) GetResidualRoots() []*DelayedBundleApplication

func (*ProcessBundleSplitResponse) ProtoMessage

func (*ProcessBundleSplitResponse) ProtoMessage()

func (*ProcessBundleSplitResponse) ProtoReflect

func (*ProcessBundleSplitResponse) Reset

func (x *ProcessBundleSplitResponse) Reset()

func (*ProcessBundleSplitResponse) String

func (x *ProcessBundleSplitResponse) String() string

type ProcessBundleSplitResponse_ChannelSplit

type ProcessBundleSplitResponse_ChannelSplit struct {

	// (Required) The grpc read transform reading this channel.
	TransformId string `protobuf:"bytes,1,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// The last element of the input channel that should be entirely considered
	// part of the primary, identified by its absolute index in the (ordered)
	// channel.
	LastPrimaryElement int64 `protobuf:"varint,2,opt,name=last_primary_element,json=lastPrimaryElement,proto3" json:"last_primary_element,omitempty"`
	// The first element of the input channel that should be entirely considered
	// part of the residual, identified by its absolute index in the (ordered)
	// channel.
	FirstResidualElement int64 `protobuf:"varint,3,opt,name=first_residual_element,json=firstResidualElement,proto3" json:"first_residual_element,omitempty"`
	// contains filtered or unexported fields
}

Represents contiguous portions of the data channel that are either entirely processed or entirely unprocessed and belong to the primary or residual respectively.

This affords both a more efficient representation over the FnAPI (if the bundle is large) and often a more efficient representation on the runner side (e.g. if the set of elements can be represented as some range in an underlying dataset).

func (*ProcessBundleSplitResponse_ChannelSplit) Descriptor deprecated

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

Deprecated: Use ProcessBundleSplitResponse_ChannelSplit.ProtoReflect.Descriptor instead.

func (*ProcessBundleSplitResponse_ChannelSplit) GetFirstResidualElement

func (x *ProcessBundleSplitResponse_ChannelSplit) GetFirstResidualElement() int64

func (*ProcessBundleSplitResponse_ChannelSplit) GetLastPrimaryElement

func (x *ProcessBundleSplitResponse_ChannelSplit) GetLastPrimaryElement() int64

func (*ProcessBundleSplitResponse_ChannelSplit) GetTransformId

func (x *ProcessBundleSplitResponse_ChannelSplit) GetTransformId() string

func (*ProcessBundleSplitResponse_ChannelSplit) ProtoMessage

func (*ProcessBundleSplitResponse_ChannelSplit) ProtoReflect

func (*ProcessBundleSplitResponse_ChannelSplit) Reset

func (*ProcessBundleSplitResponse_ChannelSplit) String

type ProvisionInfo

type ProvisionInfo struct {

	// (required) Pipeline options. For non-template jobs, the options are
	// identical to what is passed to job submission.
	PipelineOptions *_struct.Struct `protobuf:"bytes,3,opt,name=pipeline_options,json=pipelineOptions,proto3" json:"pipeline_options,omitempty"`
	// (required) The artifact retrieval token produced by
	// LegacyArtifactStagingService.CommitManifestResponse.
	RetrievalToken string `protobuf:"bytes,6,opt,name=retrieval_token,json=retrievalToken,proto3" json:"retrieval_token,omitempty"`
	// (optional) The endpoint that the runner is hosting for the SDK to submit
	// status reports to during pipeline execution. This field will only be
	// populated if the runner supports SDK status reports. For more details see
	// https://s.apache.org/beam-fn-api-harness-status
	StatusEndpoint *pipeline_v1.ApiServiceDescriptor `protobuf:"bytes,7,opt,name=status_endpoint,json=statusEndpoint,proto3" json:"status_endpoint,omitempty"`
	// (optional) The logging endpoint this SDK should use.
	LoggingEndpoint *pipeline_v1.ApiServiceDescriptor `protobuf:"bytes,8,opt,name=logging_endpoint,json=loggingEndpoint,proto3" json:"logging_endpoint,omitempty"`
	// (optional) The artifact retrieval endpoint this SDK should use.
	ArtifactEndpoint *pipeline_v1.ApiServiceDescriptor `protobuf:"bytes,9,opt,name=artifact_endpoint,json=artifactEndpoint,proto3" json:"artifact_endpoint,omitempty"`
	// (optional) The control endpoint this SDK should use.
	ControlEndpoint *pipeline_v1.ApiServiceDescriptor `protobuf:"bytes,10,opt,name=control_endpoint,json=controlEndpoint,proto3" json:"control_endpoint,omitempty"`
	// The set of dependencies that should be staged into this environment.
	Dependencies []*pipeline_v1.ArtifactInformation `protobuf:"bytes,11,rep,name=dependencies,proto3" json:"dependencies,omitempty"`
	// (optional) A set of capabilities that this SDK is allowed to use in its
	// interactions with this runner.
	RunnerCapabilities []string `protobuf:"bytes,12,rep,name=runner_capabilities,json=runnerCapabilities,proto3" json:"runner_capabilities,omitempty"`
	// (optional) Runtime environment metadata that are static throughout the
	// pipeline execution.
	Metadata map[string]string `` /* 158-byte string literal not displayed */
	// contains filtered or unexported fields
}

Runtime provisioning information for a SDK harness worker instance, such as pipeline options, resource constraints and other job metadata

func (*ProvisionInfo) Descriptor deprecated

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

Deprecated: Use ProvisionInfo.ProtoReflect.Descriptor instead.

func (*ProvisionInfo) GetArtifactEndpoint

func (x *ProvisionInfo) GetArtifactEndpoint() *pipeline_v1.ApiServiceDescriptor

func (*ProvisionInfo) GetControlEndpoint

func (x *ProvisionInfo) GetControlEndpoint() *pipeline_v1.ApiServiceDescriptor

func (*ProvisionInfo) GetDependencies

func (x *ProvisionInfo) GetDependencies() []*pipeline_v1.ArtifactInformation

func (*ProvisionInfo) GetLoggingEndpoint

func (x *ProvisionInfo) GetLoggingEndpoint() *pipeline_v1.ApiServiceDescriptor

func (*ProvisionInfo) GetMetadata

func (x *ProvisionInfo) GetMetadata() map[string]string

func (*ProvisionInfo) GetPipelineOptions

func (x *ProvisionInfo) GetPipelineOptions() *_struct.Struct

func (*ProvisionInfo) GetRetrievalToken

func (x *ProvisionInfo) GetRetrievalToken() string

func (*ProvisionInfo) GetRunnerCapabilities

func (x *ProvisionInfo) GetRunnerCapabilities() []string

func (*ProvisionInfo) GetStatusEndpoint

func (x *ProvisionInfo) GetStatusEndpoint() *pipeline_v1.ApiServiceDescriptor

func (*ProvisionInfo) ProtoMessage

func (*ProvisionInfo) ProtoMessage()

func (*ProvisionInfo) ProtoReflect

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

func (*ProvisionInfo) Reset

func (x *ProvisionInfo) Reset()

func (*ProvisionInfo) String

func (x *ProvisionInfo) String() string

type ProvisionServiceClient

type ProvisionServiceClient interface {
	// Get provision information for the SDK harness worker instance.
	GetProvisionInfo(ctx context.Context, in *GetProvisionInfoRequest, opts ...grpc.CallOption) (*GetProvisionInfoResponse, error)
}

ProvisionServiceClient is the client API for ProvisionService service.

For semantics around ctx use and closing/ending streaming RPCs, please refer to https://godoc.org/google.golang.org/grpc#ClientConn.NewStream.

type ProvisionServiceServer

type ProvisionServiceServer interface {
	// Get provision information for the SDK harness worker instance.
	GetProvisionInfo(context.Context, *GetProvisionInfoRequest) (*GetProvisionInfoResponse, error)
}

ProvisionServiceServer is the server API for ProvisionService service.

type RegisterRequest

type RegisterRequest struct {

	// (Optional) The set of descriptors used to process bundles.
	ProcessBundleDescriptor []*ProcessBundleDescriptor `` /* 132-byte string literal not displayed */
	// contains filtered or unexported fields
}

A list of objects which can be referred to by the runner in future requests. Stable

func (*RegisterRequest) Descriptor deprecated

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

Deprecated: Use RegisterRequest.ProtoReflect.Descriptor instead.

func (*RegisterRequest) GetProcessBundleDescriptor

func (x *RegisterRequest) GetProcessBundleDescriptor() []*ProcessBundleDescriptor

func (*RegisterRequest) ProtoMessage

func (*RegisterRequest) ProtoMessage()

func (*RegisterRequest) ProtoReflect

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

func (*RegisterRequest) Reset

func (x *RegisterRequest) Reset()

func (*RegisterRequest) String

func (x *RegisterRequest) String() string

type RegisterResponse

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

Stable

func (*RegisterResponse) Descriptor deprecated

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

Deprecated: Use RegisterResponse.ProtoReflect.Descriptor instead.

func (*RegisterResponse) ProtoMessage

func (*RegisterResponse) ProtoMessage()

func (*RegisterResponse) ProtoReflect

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

func (*RegisterResponse) Reset

func (x *RegisterResponse) Reset()

func (*RegisterResponse) String

func (x *RegisterResponse) String() string

type RemoteGrpcPort

type RemoteGrpcPort struct {

	// (Required) An API descriptor which describes where to
	// connect to including any authentication that is required.
	ApiServiceDescriptor *pipeline_v1.ApiServiceDescriptor `protobuf:"bytes,1,opt,name=api_service_descriptor,json=apiServiceDescriptor,proto3" json:"api_service_descriptor,omitempty"`
	// (Required) The ID of the Coder that will be used to encode and decode data
	// sent over this port.
	CoderId string `protobuf:"bytes,2,opt,name=coder_id,json=coderId,proto3" json:"coder_id,omitempty"`
	// contains filtered or unexported fields
}

A descriptor for connecting to a remote port using the Beam Fn Data API. Allows for communication between two environments (for example between the runner and the SDK). Stable

func (*RemoteGrpcPort) Descriptor deprecated

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

Deprecated: Use RemoteGrpcPort.ProtoReflect.Descriptor instead.

func (*RemoteGrpcPort) GetApiServiceDescriptor

func (x *RemoteGrpcPort) GetApiServiceDescriptor() *pipeline_v1.ApiServiceDescriptor

func (*RemoteGrpcPort) GetCoderId

func (x *RemoteGrpcPort) GetCoderId() string

func (*RemoteGrpcPort) ProtoMessage

func (*RemoteGrpcPort) ProtoMessage()

func (*RemoteGrpcPort) ProtoReflect

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

func (*RemoteGrpcPort) Reset

func (x *RemoteGrpcPort) Reset()

func (*RemoteGrpcPort) String

func (x *RemoteGrpcPort) String() string

type StartWorkerRequest

type StartWorkerRequest struct {
	WorkerId          string                            `protobuf:"bytes,1,opt,name=worker_id,json=workerId,proto3" json:"worker_id,omitempty"`
	ControlEndpoint   *pipeline_v1.ApiServiceDescriptor `protobuf:"bytes,2,opt,name=control_endpoint,json=controlEndpoint,proto3" json:"control_endpoint,omitempty"`
	LoggingEndpoint   *pipeline_v1.ApiServiceDescriptor `protobuf:"bytes,3,opt,name=logging_endpoint,json=loggingEndpoint,proto3" json:"logging_endpoint,omitempty"`
	ArtifactEndpoint  *pipeline_v1.ApiServiceDescriptor `protobuf:"bytes,4,opt,name=artifact_endpoint,json=artifactEndpoint,proto3" json:"artifact_endpoint,omitempty"`
	ProvisionEndpoint *pipeline_v1.ApiServiceDescriptor `protobuf:"bytes,5,opt,name=provision_endpoint,json=provisionEndpoint,proto3" json:"provision_endpoint,omitempty"`
	Params            map[string]string                 `` /* 154-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*StartWorkerRequest) Descriptor deprecated

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

Deprecated: Use StartWorkerRequest.ProtoReflect.Descriptor instead.

func (*StartWorkerRequest) GetArtifactEndpoint

func (x *StartWorkerRequest) GetArtifactEndpoint() *pipeline_v1.ApiServiceDescriptor

func (*StartWorkerRequest) GetControlEndpoint

func (x *StartWorkerRequest) GetControlEndpoint() *pipeline_v1.ApiServiceDescriptor

func (*StartWorkerRequest) GetLoggingEndpoint

func (x *StartWorkerRequest) GetLoggingEndpoint() *pipeline_v1.ApiServiceDescriptor

func (*StartWorkerRequest) GetParams

func (x *StartWorkerRequest) GetParams() map[string]string

func (*StartWorkerRequest) GetProvisionEndpoint

func (x *StartWorkerRequest) GetProvisionEndpoint() *pipeline_v1.ApiServiceDescriptor

func (*StartWorkerRequest) GetWorkerId

func (x *StartWorkerRequest) GetWorkerId() string

func (*StartWorkerRequest) ProtoMessage

func (*StartWorkerRequest) ProtoMessage()

func (*StartWorkerRequest) ProtoReflect

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

func (*StartWorkerRequest) Reset

func (x *StartWorkerRequest) Reset()

func (*StartWorkerRequest) String

func (x *StartWorkerRequest) String() string

type StartWorkerResponse

type StartWorkerResponse struct {
	Error string `protobuf:"bytes,1,opt,name=error,proto3" json:"error,omitempty"`
	// contains filtered or unexported fields
}

func (*StartWorkerResponse) Descriptor deprecated

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

Deprecated: Use StartWorkerResponse.ProtoReflect.Descriptor instead.

func (*StartWorkerResponse) GetError

func (x *StartWorkerResponse) GetError() string

func (*StartWorkerResponse) ProtoMessage

func (*StartWorkerResponse) ProtoMessage()

func (*StartWorkerResponse) ProtoReflect

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

func (*StartWorkerResponse) Reset

func (x *StartWorkerResponse) Reset()

func (*StartWorkerResponse) String

func (x *StartWorkerResponse) String() string

type StateAppendRequest

type StateAppendRequest struct {

	// Represents a part of a logical byte stream. Elements within
	// the logical byte stream are encoded in the nested context and
	// multiple append requests are concatenated together.
	Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"`
	// contains filtered or unexported fields
}

A request to append state.

func (*StateAppendRequest) Descriptor deprecated

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

Deprecated: Use StateAppendRequest.ProtoReflect.Descriptor instead.

func (*StateAppendRequest) GetData

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

func (*StateAppendRequest) ProtoMessage

func (*StateAppendRequest) ProtoMessage()

func (*StateAppendRequest) ProtoReflect

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

func (*StateAppendRequest) Reset

func (x *StateAppendRequest) Reset()

func (*StateAppendRequest) String

func (x *StateAppendRequest) String() string

type StateAppendResponse

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

A response to append state.

func (*StateAppendResponse) Descriptor deprecated

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

Deprecated: Use StateAppendResponse.ProtoReflect.Descriptor instead.

func (*StateAppendResponse) ProtoMessage

func (*StateAppendResponse) ProtoMessage()

func (*StateAppendResponse) ProtoReflect

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

func (*StateAppendResponse) Reset

func (x *StateAppendResponse) Reset()

func (*StateAppendResponse) String

func (x *StateAppendResponse) String() string

type StateClearRequest

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

A request to clear state.

func (*StateClearRequest) Descriptor deprecated

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

Deprecated: Use StateClearRequest.ProtoReflect.Descriptor instead.

func (*StateClearRequest) ProtoMessage

func (*StateClearRequest) ProtoMessage()

func (*StateClearRequest) ProtoReflect

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

func (*StateClearRequest) Reset

func (x *StateClearRequest) Reset()

func (*StateClearRequest) String

func (x *StateClearRequest) String() string

type StateClearResponse

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

A response to clear state.

func (*StateClearResponse) Descriptor deprecated

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

Deprecated: Use StateClearResponse.ProtoReflect.Descriptor instead.

func (*StateClearResponse) ProtoMessage

func (*StateClearResponse) ProtoMessage()

func (*StateClearResponse) ProtoReflect

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

func (*StateClearResponse) Reset

func (x *StateClearResponse) Reset()

func (*StateClearResponse) String

func (x *StateClearResponse) String() string

type StateGetRequest

type StateGetRequest struct {

	// (Optional) If specified, signals to the runner that the response
	// should resume from the following continuation token.
	//
	// If unspecified, signals to the runner that the response should start
	// from the beginning of the logical continuable stream.
	ContinuationToken []byte `protobuf:"bytes,1,opt,name=continuation_token,json=continuationToken,proto3" json:"continuation_token,omitempty"`
	// contains filtered or unexported fields
}

A request to get state.

func (*StateGetRequest) Descriptor deprecated

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

Deprecated: Use StateGetRequest.ProtoReflect.Descriptor instead.

func (*StateGetRequest) GetContinuationToken

func (x *StateGetRequest) GetContinuationToken() []byte

func (*StateGetRequest) ProtoMessage

func (*StateGetRequest) ProtoMessage()

func (*StateGetRequest) ProtoReflect

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

func (*StateGetRequest) Reset

func (x *StateGetRequest) Reset()

func (*StateGetRequest) String

func (x *StateGetRequest) String() string

type StateGetResponse

type StateGetResponse struct {

	// (Optional) If specified, represents a token which can be used with the
	// state API to get the next chunk of this logical byte stream. The end of
	// the logical byte stream is signalled by this field being unset.
	ContinuationToken []byte `protobuf:"bytes,1,opt,name=continuation_token,json=continuationToken,proto3" json:"continuation_token,omitempty"`
	// Represents a part of a logical byte stream. Elements within
	// the logical byte stream are encoded in the nested context and
	// concatenated together.
	Data []byte `protobuf:"bytes,2,opt,name=data,proto3" json:"data,omitempty"`
	// contains filtered or unexported fields
}

A response to get state representing a logical byte stream which can be continued using the state API.

func (*StateGetResponse) Descriptor deprecated

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

Deprecated: Use StateGetResponse.ProtoReflect.Descriptor instead.

func (*StateGetResponse) GetContinuationToken

func (x *StateGetResponse) GetContinuationToken() []byte

func (*StateGetResponse) GetData

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

func (*StateGetResponse) ProtoMessage

func (*StateGetResponse) ProtoMessage()

func (*StateGetResponse) ProtoReflect

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

func (*StateGetResponse) Reset

func (x *StateGetResponse) Reset()

func (*StateGetResponse) String

func (x *StateGetResponse) String() string

type StateKey

type StateKey struct {

	// (Required) One of the following state keys must be set.
	//
	// Types that are assignable to Type:
	//	*StateKey_Runner_
	//	*StateKey_MultimapSideInput_
	//	*StateKey_BagUserState_
	//	*StateKey_IterableSideInput_
	//	*StateKey_MultimapKeysSideInput_
	Type isStateKey_Type `protobuf_oneof:"type"`
	// contains filtered or unexported fields
}

func (*StateKey) Descriptor deprecated

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

Deprecated: Use StateKey.ProtoReflect.Descriptor instead.

func (*StateKey) GetBagUserState

func (x *StateKey) GetBagUserState() *StateKey_BagUserState

func (*StateKey) GetIterableSideInput

func (x *StateKey) GetIterableSideInput() *StateKey_IterableSideInput

func (*StateKey) GetMultimapKeysSideInput

func (x *StateKey) GetMultimapKeysSideInput() *StateKey_MultimapKeysSideInput

func (*StateKey) GetMultimapSideInput

func (x *StateKey) GetMultimapSideInput() *StateKey_MultimapSideInput

func (*StateKey) GetRunner

func (x *StateKey) GetRunner() *StateKey_Runner

func (*StateKey) GetType

func (m *StateKey) GetType() isStateKey_Type

func (*StateKey) ProtoMessage

func (*StateKey) ProtoMessage()

func (*StateKey) ProtoReflect

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

func (*StateKey) Reset

func (x *StateKey) Reset()

func (*StateKey) String

func (x *StateKey) String() string

type StateKey_BagUserState

type StateKey_BagUserState struct {

	// (Required) The id of the PTransform containing user state.
	TransformId string `protobuf:"bytes,1,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Required) The id of the user state.
	UserStateId string `protobuf:"bytes,2,opt,name=user_state_id,json=userStateId,proto3" json:"user_state_id,omitempty"`
	// (Required) The window encoded in a nested context.
	Window []byte `protobuf:"bytes,3,opt,name=window,proto3" json:"window,omitempty"`
	// (Required) The key of the currently executing element encoded in a
	// nested context.
	Key []byte `protobuf:"bytes,4,opt,name=key,proto3" json:"key,omitempty"`
	// contains filtered or unexported fields
}

func (*StateKey_BagUserState) Descriptor deprecated

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

Deprecated: Use StateKey_BagUserState.ProtoReflect.Descriptor instead.

func (*StateKey_BagUserState) GetKey

func (x *StateKey_BagUserState) GetKey() []byte

func (*StateKey_BagUserState) GetTransformId

func (x *StateKey_BagUserState) GetTransformId() string

func (*StateKey_BagUserState) GetUserStateId

func (x *StateKey_BagUserState) GetUserStateId() string

func (*StateKey_BagUserState) GetWindow

func (x *StateKey_BagUserState) GetWindow() []byte

func (*StateKey_BagUserState) ProtoMessage

func (*StateKey_BagUserState) ProtoMessage()

func (*StateKey_BagUserState) ProtoReflect

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

func (*StateKey_BagUserState) Reset

func (x *StateKey_BagUserState) Reset()

func (*StateKey_BagUserState) String

func (x *StateKey_BagUserState) String() string

type StateKey_BagUserState_

type StateKey_BagUserState_ struct {
	BagUserState *StateKey_BagUserState `protobuf:"bytes,3,opt,name=bag_user_state,json=bagUserState,proto3,oneof"`
}

type StateKey_IterableSideInput

type StateKey_IterableSideInput struct {

	// (Required) The id of the PTransform containing a side input.
	TransformId string `protobuf:"bytes,1,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Required) The id of the side input.
	SideInputId string `protobuf:"bytes,2,opt,name=side_input_id,json=sideInputId,proto3" json:"side_input_id,omitempty"`
	// (Required) The window (after mapping the currently executing elements
	// window into the side input windows domain) encoded in a nested context.
	Window []byte `protobuf:"bytes,3,opt,name=window,proto3" json:"window,omitempty"`
	// contains filtered or unexported fields
}

Represents a request for the values associated with a specified window in a PCollection. See https://s.apache.org/beam-fn-state-api-and-bundle-processing for further details.

Can only be used to perform StateGetRequests on side inputs of the URN beam:side_input:iterable:v1.

For a PCollection<V>, the response data stream will be a concatenation of all V's. See https://s.apache.org/beam-fn-api-send-and-receive-data for further details.

func (*StateKey_IterableSideInput) Descriptor deprecated

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

Deprecated: Use StateKey_IterableSideInput.ProtoReflect.Descriptor instead.

func (*StateKey_IterableSideInput) GetSideInputId

func (x *StateKey_IterableSideInput) GetSideInputId() string

func (*StateKey_IterableSideInput) GetTransformId

func (x *StateKey_IterableSideInput) GetTransformId() string

func (*StateKey_IterableSideInput) GetWindow

func (x *StateKey_IterableSideInput) GetWindow() []byte

func (*StateKey_IterableSideInput) ProtoMessage

func (*StateKey_IterableSideInput) ProtoMessage()

func (*StateKey_IterableSideInput) ProtoReflect

func (*StateKey_IterableSideInput) Reset

func (x *StateKey_IterableSideInput) Reset()

func (*StateKey_IterableSideInput) String

func (x *StateKey_IterableSideInput) String() string

type StateKey_IterableSideInput_

type StateKey_IterableSideInput_ struct {
	IterableSideInput *StateKey_IterableSideInput `protobuf:"bytes,4,opt,name=iterable_side_input,json=iterableSideInput,proto3,oneof"`
}

type StateKey_MultimapKeysSideInput

type StateKey_MultimapKeysSideInput struct {

	// (Required) The id of the PTransform containing a side input.
	TransformId string `protobuf:"bytes,1,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Required) The id of the side input.
	SideInputId string `protobuf:"bytes,2,opt,name=side_input_id,json=sideInputId,proto3" json:"side_input_id,omitempty"`
	// (Required) The window (after mapping the currently executing elements
	// window into the side input windows domain) encoded in a nested context.
	Window []byte `protobuf:"bytes,3,opt,name=window,proto3" json:"window,omitempty"`
	// contains filtered or unexported fields
}

Represents a request for the keys associated with a specified window in a PCollection. See https://s.apache.org/beam-fn-state-api-and-bundle-processing for further details.

Can only be used to perform StateGetRequests on side inputs of the URN beam:side_input:multimap:v1.

For a PCollection<KV<K, V>>, the response data stream will be a concatenation of all K's associated with the specified window. See https://s.apache.org/beam-fn-api-send-and-receive-data for further details.

func (*StateKey_MultimapKeysSideInput) Descriptor deprecated

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

Deprecated: Use StateKey_MultimapKeysSideInput.ProtoReflect.Descriptor instead.

func (*StateKey_MultimapKeysSideInput) GetSideInputId

func (x *StateKey_MultimapKeysSideInput) GetSideInputId() string

func (*StateKey_MultimapKeysSideInput) GetTransformId

func (x *StateKey_MultimapKeysSideInput) GetTransformId() string

func (*StateKey_MultimapKeysSideInput) GetWindow

func (x *StateKey_MultimapKeysSideInput) GetWindow() []byte

func (*StateKey_MultimapKeysSideInput) ProtoMessage

func (*StateKey_MultimapKeysSideInput) ProtoMessage()

func (*StateKey_MultimapKeysSideInput) ProtoReflect

func (*StateKey_MultimapKeysSideInput) Reset

func (x *StateKey_MultimapKeysSideInput) Reset()

func (*StateKey_MultimapKeysSideInput) String

type StateKey_MultimapKeysSideInput_

type StateKey_MultimapKeysSideInput_ struct {
	MultimapKeysSideInput *StateKey_MultimapKeysSideInput `protobuf:"bytes,5,opt,name=multimap_keys_side_input,json=multimapKeysSideInput,proto3,oneof"` // TODO: represent a state key for user map state
}

type StateKey_MultimapSideInput

type StateKey_MultimapSideInput struct {

	// (Required) The id of the PTransform containing a side input.
	TransformId string `protobuf:"bytes,1,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Required) The id of the side input.
	SideInputId string `protobuf:"bytes,2,opt,name=side_input_id,json=sideInputId,proto3" json:"side_input_id,omitempty"`
	// (Required) The window (after mapping the currently executing elements
	// window into the side input windows domain) encoded in a nested context.
	Window []byte `protobuf:"bytes,3,opt,name=window,proto3" json:"window,omitempty"`
	// (Required) The key encoded in a nested context.
	Key []byte `protobuf:"bytes,4,opt,name=key,proto3" json:"key,omitempty"`
	// contains filtered or unexported fields
}

Represents a request for the values associated with a specified user key and window in a PCollection. See https://s.apache.org/beam-fn-state-api-and-bundle-processing for further details.

Can only be used to perform StateGetRequests on side inputs of the URN beam:side_input:multimap:v1.

For a PCollection<KV<K, V>>, the response data stream will be a concatenation of all V's associated with the specified key K. See https://s.apache.org/beam-fn-api-send-and-receive-data for further details.

func (*StateKey_MultimapSideInput) Descriptor deprecated

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

Deprecated: Use StateKey_MultimapSideInput.ProtoReflect.Descriptor instead.

func (*StateKey_MultimapSideInput) GetKey

func (x *StateKey_MultimapSideInput) GetKey() []byte

func (*StateKey_MultimapSideInput) GetSideInputId

func (x *StateKey_MultimapSideInput) GetSideInputId() string

func (*StateKey_MultimapSideInput) GetTransformId

func (x *StateKey_MultimapSideInput) GetTransformId() string

func (*StateKey_MultimapSideInput) GetWindow

func (x *StateKey_MultimapSideInput) GetWindow() []byte

func (*StateKey_MultimapSideInput) ProtoMessage

func (*StateKey_MultimapSideInput) ProtoMessage()

func (*StateKey_MultimapSideInput) ProtoReflect

func (*StateKey_MultimapSideInput) Reset

func (x *StateKey_MultimapSideInput) Reset()

func (*StateKey_MultimapSideInput) String

func (x *StateKey_MultimapSideInput) String() string

type StateKey_MultimapSideInput_

type StateKey_MultimapSideInput_ struct {
	MultimapSideInput *StateKey_MultimapSideInput `protobuf:"bytes,2,opt,name=multimap_side_input,json=multimapSideInput,proto3,oneof"`
}

type StateKey_Runner

type StateKey_Runner struct {

	// (Required) Opaque information supplied by the runner. Used to support
	// remote references.
	// https://s.apache.org/beam-fn-api-send-and-receive-data
	//
	// Used by state backed iterable. And in this use case, request type can
	// only be of type get. Details see:
	// https://s.apache.org/beam-fn-api-state-backed-iterables
	Key []byte `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"`
	// contains filtered or unexported fields
}

func (*StateKey_Runner) Descriptor deprecated

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

Deprecated: Use StateKey_Runner.ProtoReflect.Descriptor instead.

func (*StateKey_Runner) GetKey

func (x *StateKey_Runner) GetKey() []byte

func (*StateKey_Runner) ProtoMessage

func (*StateKey_Runner) ProtoMessage()

func (*StateKey_Runner) ProtoReflect

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

func (*StateKey_Runner) Reset

func (x *StateKey_Runner) Reset()

func (*StateKey_Runner) String

func (x *StateKey_Runner) String() string

type StateKey_Runner_

type StateKey_Runner_ struct {
	Runner *StateKey_Runner `protobuf:"bytes,1,opt,name=runner,proto3,oneof"`
}

type StateRequest

type StateRequest struct {

	// (Required) A unique identifier provided by the SDK which represents this
	// requests execution. The StateResponse corresponding with this request
	// will have the matching id.
	Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	// (Required) The associated instruction id of the work that is currently
	// being processed. This allows for the runner to associate any modifications
	// to state to be committed with the appropriate work execution.
	InstructionId string `protobuf:"bytes,2,opt,name=instruction_id,json=instructionId,proto3" json:"instruction_id,omitempty"`
	// (Required) The state key this request is for.
	StateKey *StateKey `protobuf:"bytes,3,opt,name=state_key,json=stateKey,proto3" json:"state_key,omitempty"`
	// (Required) The action to take on this request.
	//
	// Types that are assignable to Request:
	//	*StateRequest_Get
	//	*StateRequest_Append
	//	*StateRequest_Clear
	Request isStateRequest_Request `protobuf_oneof:"request"`
	// contains filtered or unexported fields
}

func (*StateRequest) Descriptor deprecated

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

Deprecated: Use StateRequest.ProtoReflect.Descriptor instead.

func (*StateRequest) GetAppend

func (x *StateRequest) GetAppend() *StateAppendRequest

func (*StateRequest) GetClear

func (x *StateRequest) GetClear() *StateClearRequest

func (*StateRequest) GetGet

func (x *StateRequest) GetGet() *StateGetRequest

func (*StateRequest) GetId

func (x *StateRequest) GetId() string

func (*StateRequest) GetInstructionId

func (x *StateRequest) GetInstructionId() string

func (*StateRequest) GetRequest

func (m *StateRequest) GetRequest() isStateRequest_Request

func (*StateRequest) GetStateKey

func (x *StateRequest) GetStateKey() *StateKey

func (*StateRequest) ProtoMessage

func (*StateRequest) ProtoMessage()

func (*StateRequest) ProtoReflect

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

func (*StateRequest) Reset

func (x *StateRequest) Reset()

func (*StateRequest) String

func (x *StateRequest) String() string

type StateRequest_Append

type StateRequest_Append struct {
	// A request to append to state.
	Append *StateAppendRequest `protobuf:"bytes,1001,opt,name=append,proto3,oneof"`
}

type StateRequest_Clear

type StateRequest_Clear struct {
	// A request to clear state.
	Clear *StateClearRequest `protobuf:"bytes,1002,opt,name=clear,proto3,oneof"`
}

type StateRequest_Get

type StateRequest_Get struct {
	// A request to get state.
	Get *StateGetRequest `protobuf:"bytes,1000,opt,name=get,proto3,oneof"`
}

type StateResponse

type StateResponse struct {

	// (Required) A reference provided by the SDK which represents a requests
	// execution. The StateResponse must have the matching id when responding
	// to the SDK.
	Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	// (Optional) If this is specified, then the state request has failed.
	// A human readable string representing the reason as to why the request
	// failed.
	Error string `protobuf:"bytes,2,opt,name=error,proto3" json:"error,omitempty"`
	// A corresponding response matching the request will be populated.
	//
	// Types that are assignable to Response:
	//	*StateResponse_Get
	//	*StateResponse_Append
	//	*StateResponse_Clear
	Response isStateResponse_Response `protobuf_oneof:"response"`
	// contains filtered or unexported fields
}

func (*StateResponse) Descriptor deprecated

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

Deprecated: Use StateResponse.ProtoReflect.Descriptor instead.

func (*StateResponse) GetAppend

func (x *StateResponse) GetAppend() *StateAppendResponse

func (*StateResponse) GetClear

func (x *StateResponse) GetClear() *StateClearResponse

func (*StateResponse) GetError

func (x *StateResponse) GetError() string

func (*StateResponse) GetGet

func (x *StateResponse) GetGet() *StateGetResponse

func (*StateResponse) GetId

func (x *StateResponse) GetId() string

func (*StateResponse) GetResponse

func (m *StateResponse) GetResponse() isStateResponse_Response

func (*StateResponse) ProtoMessage

func (*StateResponse) ProtoMessage()

func (*StateResponse) ProtoReflect

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

func (*StateResponse) Reset

func (x *StateResponse) Reset()

func (*StateResponse) String

func (x *StateResponse) String() string

type StateResponse_Append

type StateResponse_Append struct {
	// A response to appending to state.
	Append *StateAppendResponse `protobuf:"bytes,1001,opt,name=append,proto3,oneof"`
}

type StateResponse_Clear

type StateResponse_Clear struct {
	// A response to clearing state.
	Clear *StateClearResponse `protobuf:"bytes,1002,opt,name=clear,proto3,oneof"`
}

type StateResponse_Get

type StateResponse_Get struct {
	// A response to getting state.
	Get *StateGetResponse `protobuf:"bytes,1000,opt,name=get,proto3,oneof"`
}

type StopWorkerRequest

type StopWorkerRequest struct {
	WorkerId string `protobuf:"bytes,1,opt,name=worker_id,json=workerId,proto3" json:"worker_id,omitempty"`
	// contains filtered or unexported fields
}

func (*StopWorkerRequest) Descriptor deprecated

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

Deprecated: Use StopWorkerRequest.ProtoReflect.Descriptor instead.

func (*StopWorkerRequest) GetWorkerId

func (x *StopWorkerRequest) GetWorkerId() string

func (*StopWorkerRequest) ProtoMessage

func (*StopWorkerRequest) ProtoMessage()

func (*StopWorkerRequest) ProtoReflect

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

func (*StopWorkerRequest) Reset

func (x *StopWorkerRequest) Reset()

func (*StopWorkerRequest) String

func (x *StopWorkerRequest) String() string

type StopWorkerResponse

type StopWorkerResponse struct {
	Error string `protobuf:"bytes,1,opt,name=error,proto3" json:"error,omitempty"`
	// contains filtered or unexported fields
}

func (*StopWorkerResponse) Descriptor deprecated

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

Deprecated: Use StopWorkerResponse.ProtoReflect.Descriptor instead.

func (*StopWorkerResponse) GetError

func (x *StopWorkerResponse) GetError() string

func (*StopWorkerResponse) ProtoMessage

func (*StopWorkerResponse) ProtoMessage()

func (*StopWorkerResponse) ProtoReflect

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

func (*StopWorkerResponse) Reset

func (x *StopWorkerResponse) Reset()

func (*StopWorkerResponse) String

func (x *StopWorkerResponse) String() string

type UnimplementedBeamFnControlServer

type UnimplementedBeamFnControlServer struct {
}

UnimplementedBeamFnControlServer can be embedded to have forward compatible implementations.

func (*UnimplementedBeamFnControlServer) Control

func (*UnimplementedBeamFnControlServer) GetProcessBundleDescriptor

type UnimplementedBeamFnDataServer

type UnimplementedBeamFnDataServer struct {
}

UnimplementedBeamFnDataServer can be embedded to have forward compatible implementations.

func (*UnimplementedBeamFnDataServer) Data

type UnimplementedBeamFnExternalWorkerPoolServer

type UnimplementedBeamFnExternalWorkerPoolServer struct {
}

UnimplementedBeamFnExternalWorkerPoolServer can be embedded to have forward compatible implementations.

func (*UnimplementedBeamFnExternalWorkerPoolServer) StartWorker

func (*UnimplementedBeamFnExternalWorkerPoolServer) StopWorker

type UnimplementedBeamFnLoggingServer

type UnimplementedBeamFnLoggingServer struct {
}

UnimplementedBeamFnLoggingServer can be embedded to have forward compatible implementations.

func (*UnimplementedBeamFnLoggingServer) Logging

type UnimplementedBeamFnStateServer

type UnimplementedBeamFnStateServer struct {
}

UnimplementedBeamFnStateServer can be embedded to have forward compatible implementations.

func (*UnimplementedBeamFnStateServer) State

type UnimplementedBeamFnWorkerStatusServer

type UnimplementedBeamFnWorkerStatusServer struct {
}

UnimplementedBeamFnWorkerStatusServer can be embedded to have forward compatible implementations.

func (*UnimplementedBeamFnWorkerStatusServer) WorkerStatus

type UnimplementedProvisionServiceServer

type UnimplementedProvisionServiceServer struct {
}

UnimplementedProvisionServiceServer can be embedded to have forward compatible implementations.

func (*UnimplementedProvisionServiceServer) GetProvisionInfo

type WorkerStatusRequest

type WorkerStatusRequest struct {

	// (Required) Unique ID identifying this request.
	Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	// contains filtered or unexported fields
}

Request from runner to SDK Harness asking for its status. For more details see https://s.apache.org/beam-fn-api-harness-status

func (*WorkerStatusRequest) Descriptor deprecated

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

Deprecated: Use WorkerStatusRequest.ProtoReflect.Descriptor instead.

func (*WorkerStatusRequest) GetId

func (x *WorkerStatusRequest) GetId() string

func (*WorkerStatusRequest) ProtoMessage

func (*WorkerStatusRequest) ProtoMessage()

func (*WorkerStatusRequest) ProtoReflect

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

func (*WorkerStatusRequest) Reset

func (x *WorkerStatusRequest) Reset()

func (*WorkerStatusRequest) String

func (x *WorkerStatusRequest) String() string

type WorkerStatusResponse

type WorkerStatusResponse struct {

	// (Required) Unique ID from the original request.
	Id string `protobuf:"bytes,1,opt,name=id,proto3" json:"id,omitempty"`
	// (Optional) Error message if exception encountered generating the status response.
	Error string `protobuf:"bytes,2,opt,name=error,proto3" json:"error,omitempty"`
	// (Optional) Status debugging info reported by SDK harness worker. Content and
	// format is not strongly enforced but should be print-friendly and
	// appropriate as an HTTP response body for end user. For details of the preferred
	// info to include in the message see
	// https://s.apache.org/beam-fn-api-harness-status
	StatusInfo string `protobuf:"bytes,3,opt,name=status_info,json=statusInfo,proto3" json:"status_info,omitempty"`
	// contains filtered or unexported fields
}

Response from SDK Harness to runner containing the debug related status info.

func (*WorkerStatusResponse) Descriptor deprecated

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

Deprecated: Use WorkerStatusResponse.ProtoReflect.Descriptor instead.

func (*WorkerStatusResponse) GetError

func (x *WorkerStatusResponse) GetError() string

func (*WorkerStatusResponse) GetId

func (x *WorkerStatusResponse) GetId() string

func (*WorkerStatusResponse) GetStatusInfo

func (x *WorkerStatusResponse) GetStatusInfo() string

func (*WorkerStatusResponse) ProtoMessage

func (*WorkerStatusResponse) ProtoMessage()

func (*WorkerStatusResponse) ProtoReflect

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

func (*WorkerStatusResponse) Reset

func (x *WorkerStatusResponse) Reset()

func (*WorkerStatusResponse) String

func (x *WorkerStatusResponse) String() string

Jump to

Keyboard shortcuts

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