pipeline_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: 11 Imported by: 0

Documentation

Index

Constants

This section is empty.

Variables

View Source
var (
	BeamConstants_Constants_name = map[int32]string{
		0: "MIN_TIMESTAMP_MILLIS",
		1: "MAX_TIMESTAMP_MILLIS",
		2: "GLOBAL_WINDOW_MAX_TIMESTAMP_MILLIS",
	}
	BeamConstants_Constants_value = map[string]int32{
		"MIN_TIMESTAMP_MILLIS":               0,
		"MAX_TIMESTAMP_MILLIS":               1,
		"GLOBAL_WINDOW_MAX_TIMESTAMP_MILLIS": 2,
	}
)

Enum value maps for BeamConstants_Constants.

View Source
var (
	StandardPTransforms_Primitives_name = map[int32]string{
		0: "PAR_DO",
		1: "FLATTEN",
		2: "GROUP_BY_KEY",
		3: "IMPULSE",
		4: "ASSIGN_WINDOWS",
		5: "TEST_STREAM",
		6: "MAP_WINDOWS",
		7: "MERGE_WINDOWS",
		8: "TO_STRING",
	}
	StandardPTransforms_Primitives_value = map[string]int32{
		"PAR_DO":         0,
		"FLATTEN":        1,
		"GROUP_BY_KEY":   2,
		"IMPULSE":        3,
		"ASSIGN_WINDOWS": 4,
		"TEST_STREAM":    5,
		"MAP_WINDOWS":    6,
		"MERGE_WINDOWS":  7,
		"TO_STRING":      8,
	}
)

Enum value maps for StandardPTransforms_Primitives.

View Source
var (
	StandardPTransforms_DeprecatedPrimitives_name = map[int32]string{
		0: "READ",
		1: "CREATE_VIEW",
	}
	StandardPTransforms_DeprecatedPrimitives_value = map[string]int32{
		"READ":        0,
		"CREATE_VIEW": 1,
	}
)

Enum value maps for StandardPTransforms_DeprecatedPrimitives.

View Source
var (
	StandardPTransforms_Composites_name = map[int32]string{
		0: "COMBINE_PER_KEY",
		1: "COMBINE_GLOBALLY",
		2: "RESHUFFLE",
		3: "WRITE_FILES",
		4: "PUBSUB_READ",
		5: "PUBSUB_WRITE",
		6: "GROUP_INTO_BATCHES_WITH_SHARDED_KEY",
	}
	StandardPTransforms_Composites_value = map[string]int32{
		"COMBINE_PER_KEY":                     0,
		"COMBINE_GLOBALLY":                    1,
		"RESHUFFLE":                           2,
		"WRITE_FILES":                         3,
		"PUBSUB_READ":                         4,
		"PUBSUB_WRITE":                        5,
		"GROUP_INTO_BATCHES_WITH_SHARDED_KEY": 6,
	}
)

Enum value maps for StandardPTransforms_Composites.

View Source
var (
	StandardPTransforms_CombineComponents_name = map[int32]string{
		0: "COMBINE_PER_KEY_PRECOMBINE",
		1: "COMBINE_PER_KEY_MERGE_ACCUMULATORS",
		2: "COMBINE_PER_KEY_EXTRACT_OUTPUTS",
		3: "COMBINE_GROUPED_VALUES",
		4: "COMBINE_PER_KEY_CONVERT_TO_ACCUMULATORS",
	}
	StandardPTransforms_CombineComponents_value = map[string]int32{
		"COMBINE_PER_KEY_PRECOMBINE":              0,
		"COMBINE_PER_KEY_MERGE_ACCUMULATORS":      1,
		"COMBINE_PER_KEY_EXTRACT_OUTPUTS":         2,
		"COMBINE_GROUPED_VALUES":                  3,
		"COMBINE_PER_KEY_CONVERT_TO_ACCUMULATORS": 4,
	}
)

Enum value maps for StandardPTransforms_CombineComponents.

View Source
var (
	StandardPTransforms_SplittableParDoComponents_name = map[int32]string{
		0: "PAIR_WITH_RESTRICTION",
		1: "SPLIT_AND_SIZE_RESTRICTIONS",
		2: "PROCESS_SIZED_ELEMENTS_AND_RESTRICTIONS",
		3: "TRUNCATE_SIZED_RESTRICTION",
	}
	StandardPTransforms_SplittableParDoComponents_value = map[string]int32{
		"PAIR_WITH_RESTRICTION":                   0,
		"SPLIT_AND_SIZE_RESTRICTIONS":             1,
		"PROCESS_SIZED_ELEMENTS_AND_RESTRICTIONS": 2,
		"TRUNCATE_SIZED_RESTRICTION":              3,
	}
)

Enum value maps for StandardPTransforms_SplittableParDoComponents.

View Source
var (
	StandardPTransforms_GroupIntoBatchesComponents_name = map[int32]string{
		0: "GROUP_INTO_BATCHES",
	}
	StandardPTransforms_GroupIntoBatchesComponents_value = map[string]int32{
		"GROUP_INTO_BATCHES": 0,
	}
)

Enum value maps for StandardPTransforms_GroupIntoBatchesComponents.

View Source
var (
	StandardSideInputTypes_Enum_name = map[int32]string{
		0: "ITERABLE",
		1: "MULTIMAP",
	}
	StandardSideInputTypes_Enum_value = map[string]int32{
		"ITERABLE": 0,
		"MULTIMAP": 1,
	}
)

Enum value maps for StandardSideInputTypes_Enum.

View Source
var (
	IsBounded_Enum_name = map[int32]string{
		0: "UNSPECIFIED",
		1: "UNBOUNDED",
		2: "BOUNDED",
	}
	IsBounded_Enum_value = map[string]int32{
		"UNSPECIFIED": 0,
		"UNBOUNDED":   1,
		"BOUNDED":     2,
	}
)

Enum value maps for IsBounded_Enum.

View Source
var (
	StandardCoders_Enum_name = map[int32]string{
		0:  "BYTES",
		10: "STRING_UTF8",
		1:  "KV",
		12: "BOOL",
		2:  "VARINT",
		11: "DOUBLE",
		3:  "ITERABLE",
		4:  "TIMER",
		5:  "INTERVAL_WINDOW",
		6:  "LENGTH_PREFIX",
		7:  "GLOBAL_WINDOW",
		8:  "WINDOWED_VALUE",
		14: "PARAM_WINDOWED_VALUE",
		9:  "STATE_BACKED_ITERABLE",
		13: "ROW",
		15: "SHARDED_KEY",
	}
	StandardCoders_Enum_value = map[string]int32{
		"BYTES":                 0,
		"STRING_UTF8":           10,
		"KV":                    1,
		"BOOL":                  12,
		"VARINT":                2,
		"DOUBLE":                11,
		"ITERABLE":              3,
		"TIMER":                 4,
		"INTERVAL_WINDOW":       5,
		"LENGTH_PREFIX":         6,
		"GLOBAL_WINDOW":         7,
		"WINDOWED_VALUE":        8,
		"PARAM_WINDOWED_VALUE":  14,
		"STATE_BACKED_ITERABLE": 9,
		"ROW":                   13,
		"SHARDED_KEY":           15,
	}
)

Enum value maps for StandardCoders_Enum.

View Source
var (
	MergeStatus_Enum_name = map[int32]string{
		0: "UNSPECIFIED",
		1: "NON_MERGING",
		2: "NEEDS_MERGE",
		3: "ALREADY_MERGED",
	}
	MergeStatus_Enum_value = map[string]int32{
		"UNSPECIFIED":    0,
		"NON_MERGING":    1,
		"NEEDS_MERGE":    2,
		"ALREADY_MERGED": 3,
	}
)

Enum value maps for MergeStatus_Enum.

View Source
var (
	AccumulationMode_Enum_name = map[int32]string{
		0: "UNSPECIFIED",
		1: "DISCARDING",
		2: "ACCUMULATING",
		3: "RETRACTING",
	}
	AccumulationMode_Enum_value = map[string]int32{
		"UNSPECIFIED":  0,
		"DISCARDING":   1,
		"ACCUMULATING": 2,
		"RETRACTING":   3,
	}
)

Enum value maps for AccumulationMode_Enum.

View Source
var (
	ClosingBehavior_Enum_name = map[int32]string{
		0: "UNSPECIFIED",
		1: "EMIT_ALWAYS",
		2: "EMIT_IF_NONEMPTY",
	}
	ClosingBehavior_Enum_value = map[string]int32{
		"UNSPECIFIED":      0,
		"EMIT_ALWAYS":      1,
		"EMIT_IF_NONEMPTY": 2,
	}
)

Enum value maps for ClosingBehavior_Enum.

View Source
var (
	OnTimeBehavior_Enum_name = map[int32]string{
		0: "UNSPECIFIED",
		1: "FIRE_ALWAYS",
		2: "FIRE_IF_NONEMPTY",
	}
	OnTimeBehavior_Enum_value = map[string]int32{
		"UNSPECIFIED":      0,
		"FIRE_ALWAYS":      1,
		"FIRE_IF_NONEMPTY": 2,
	}
)

Enum value maps for OnTimeBehavior_Enum.

View Source
var (
	OutputTime_Enum_name = map[int32]string{
		0: "UNSPECIFIED",
		1: "END_OF_WINDOW",
		2: "LATEST_IN_PANE",
		3: "EARLIEST_IN_PANE",
	}
	OutputTime_Enum_value = map[string]int32{
		"UNSPECIFIED":      0,
		"END_OF_WINDOW":    1,
		"LATEST_IN_PANE":   2,
		"EARLIEST_IN_PANE": 3,
	}
)

Enum value maps for OutputTime_Enum.

View Source
var (
	TimeDomain_Enum_name = map[int32]string{
		0: "UNSPECIFIED",
		1: "EVENT_TIME",
		2: "PROCESSING_TIME",
	}
	TimeDomain_Enum_value = map[string]int32{
		"UNSPECIFIED":     0,
		"EVENT_TIME":      1,
		"PROCESSING_TIME": 2,
	}
)

Enum value maps for TimeDomain_Enum.

View Source
var (
	StandardArtifacts_Types_name = map[int32]string{
		0: "FILE",
		1: "URL",
		2: "EMBEDDED",
		3: "PYPI",
		4: "MAVEN",
		5: "DEFERRED",
	}
	StandardArtifacts_Types_value = map[string]int32{
		"FILE":     0,
		"URL":      1,
		"EMBEDDED": 2,
		"PYPI":     3,
		"MAVEN":    4,
		"DEFERRED": 5,
	}
)

Enum value maps for StandardArtifacts_Types.

View Source
var (
	StandardArtifacts_Roles_name = map[int32]string{
		0: "STAGING_TO",
		1: "PIP_REQUIREMENTS_FILE",
	}
	StandardArtifacts_Roles_value = map[string]int32{
		"STAGING_TO":            0,
		"PIP_REQUIREMENTS_FILE": 1,
	}
)

Enum value maps for StandardArtifacts_Roles.

View Source
var (
	StandardEnvironments_Environments_name = map[int32]string{
		0: "DOCKER",
		1: "PROCESS",
		2: "EXTERNAL",
		3: "DEFAULT",
	}
	StandardEnvironments_Environments_value = map[string]int32{
		"DOCKER":   0,
		"PROCESS":  1,
		"EXTERNAL": 2,
		"DEFAULT":  3,
	}
)

Enum value maps for StandardEnvironments_Environments.

View Source
var (
	StandardProtocols_Enum_name = map[int32]string{
		0: "LEGACY_PROGRESS_REPORTING",
		1: "PROGRESS_REPORTING",
		2: "WORKER_STATUS",
		3: "MULTI_CORE_BUNDLE_PROCESSING",
		4: "HARNESS_MONITORING_INFOS",
	}
	StandardProtocols_Enum_value = map[string]int32{
		"LEGACY_PROGRESS_REPORTING":    0,
		"PROGRESS_REPORTING":           1,
		"WORKER_STATUS":                2,
		"MULTI_CORE_BUNDLE_PROCESSING": 3,
		"HARNESS_MONITORING_INFOS":     4,
	}
)

Enum value maps for StandardProtocols_Enum.

View Source
var (
	StandardRunnerProtocols_Enum_name = map[int32]string{
		0: "MONITORING_INFO_SHORT_IDS",
	}
	StandardRunnerProtocols_Enum_value = map[string]int32{
		"MONITORING_INFO_SHORT_IDS": 0,
	}
)

Enum value maps for StandardRunnerProtocols_Enum.

View Source
var (
	StandardRequirements_Enum_name = map[int32]string{
		0: "REQUIRES_STATEFUL_PROCESSING",
		1: "REQUIRES_BUNDLE_FINALIZATION",
		2: "REQUIRES_STABLE_INPUT",
		3: "REQUIRES_TIME_SORTED_INPUT",
		4: "REQUIRES_SPLITTABLE_DOFN",
	}
	StandardRequirements_Enum_value = map[string]int32{
		"REQUIRES_STATEFUL_PROCESSING": 0,
		"REQUIRES_BUNDLE_FINALIZATION": 1,
		"REQUIRES_STABLE_INPUT":        2,
		"REQUIRES_TIME_SORTED_INPUT":   3,
		"REQUIRES_SPLITTABLE_DOFN":     4,
	}
)

Enum value maps for StandardRequirements_Enum.

View Source
var (
	StandardDisplayData_DisplayData_name = map[int32]string{
		0: "LABELLED",
	}
	StandardDisplayData_DisplayData_value = map[string]int32{
		"LABELLED": 0,
	}
)

Enum value maps for StandardDisplayData_DisplayData.

View Source
var (
	StandardResourceHints_Enum_name = map[int32]string{
		0: "ACCELERATOR",
		1: "MIN_RAM_BYTES",
	}
	StandardResourceHints_Enum_value = map[string]int32{
		"ACCELERATOR":   0,
		"MIN_RAM_BYTES": 1,
	}
)

Enum value maps for StandardResourceHints_Enum.

View Source
var (
	// An extension to be used for specifying the standard URN of various
	// pipeline entities, e.g. transforms, functions, coders etc.
	// Code should refer to the URNs of those entities by extracting
	// it from the (beam_urn) extension, rather than by hard-coding
	// the URN.
	//
	// The recommended pattern for declaring it is (exemplified by coders):
	//
	// message StandardCoders {
	//   enum Enum {
	//     BYTES = 0 [(beam_urn) = "beam:coder:bytes:v1"];
	//     ...
	//   }
	// }
	//
	// If there are multiple categories of entities of this type, use the
	// following pattern (exemplified by PTransforms):
	//
	// message StandardPTransforms {
	//   enum Primitives {
	//     ...
	//   }
	//   enum Composites {
	//     ...
	//   }
	// }
	//
	// optional string beam_urn = 185324356;
	E_BeamUrn = &file_beam_runner_api_proto_extTypes[0]
	// A value to store other constants
	//
	// optional string beam_constant = 185324357;
	E_BeamConstant = &file_beam_runner_api_proto_extTypes[1]
)

Extension fields to descriptor.EnumValueOptions.

View Source
var (
	MonitoringInfoSpecs_Enum_name = map[int32]string{
		0:  "USER_SUM_INT64",
		1:  "USER_SUM_DOUBLE",
		2:  "USER_DISTRIBUTION_INT64",
		3:  "USER_DISTRIBUTION_DOUBLE",
		4:  "USER_LATEST_INT64",
		5:  "USER_LATEST_DOUBLE",
		6:  "USER_TOP_N_INT64",
		7:  "USER_TOP_N_DOUBLE",
		8:  "USER_BOTTOM_N_INT64",
		9:  "USER_BOTTOM_N_DOUBLE",
		10: "ELEMENT_COUNT",
		11: "SAMPLED_BYTE_SIZE",
		12: "START_BUNDLE_MSECS",
		13: "PROCESS_BUNDLE_MSECS",
		14: "FINISH_BUNDLE_MSECS",
		15: "TOTAL_MSECS",
		16: "WORK_REMAINING",
		17: "WORK_COMPLETED",
		18: "DATA_CHANNEL_READ_INDEX",
		19: "API_REQUEST_COUNT",
		20: "API_REQUEST_LATENCIES",
	}
	MonitoringInfoSpecs_Enum_value = map[string]int32{
		"USER_SUM_INT64":           0,
		"USER_SUM_DOUBLE":          1,
		"USER_DISTRIBUTION_INT64":  2,
		"USER_DISTRIBUTION_DOUBLE": 3,
		"USER_LATEST_INT64":        4,
		"USER_LATEST_DOUBLE":       5,
		"USER_TOP_N_INT64":         6,
		"USER_TOP_N_DOUBLE":        7,
		"USER_BOTTOM_N_INT64":      8,
		"USER_BOTTOM_N_DOUBLE":     9,
		"ELEMENT_COUNT":            10,
		"SAMPLED_BYTE_SIZE":        11,
		"START_BUNDLE_MSECS":       12,
		"PROCESS_BUNDLE_MSECS":     13,
		"FINISH_BUNDLE_MSECS":      14,
		"TOTAL_MSECS":              15,
		"WORK_REMAINING":           16,
		"WORK_COMPLETED":           17,
		"DATA_CHANNEL_READ_INDEX":  18,
		"API_REQUEST_COUNT":        19,
		"API_REQUEST_LATENCIES":    20,
	}
)

Enum value maps for MonitoringInfoSpecs_Enum.

View Source
var (
	MonitoringInfo_MonitoringInfoLabels_name = map[int32]string{
		0:  "TRANSFORM",
		1:  "PCOLLECTION",
		2:  "WINDOWING_STRATEGY",
		3:  "CODER",
		4:  "ENVIRONMENT",
		5:  "NAMESPACE",
		6:  "NAME",
		7:  "SERVICE",
		8:  "METHOD",
		9:  "RESOURCE",
		10: "STATUS",
		11: "BIGQUERY_PROJECT_ID",
		12: "BIGQUERY_DATASET",
		13: "BIGQUERY_TABLE",
		14: "BIGQUERY_VIEW",
		15: "BIGQUERY_QUERY_NAME",
	}
	MonitoringInfo_MonitoringInfoLabels_value = map[string]int32{
		"TRANSFORM":           0,
		"PCOLLECTION":         1,
		"WINDOWING_STRATEGY":  2,
		"CODER":               3,
		"ENVIRONMENT":         4,
		"NAMESPACE":           5,
		"NAME":                6,
		"SERVICE":             7,
		"METHOD":              8,
		"RESOURCE":            9,
		"STATUS":              10,
		"BIGQUERY_PROJECT_ID": 11,
		"BIGQUERY_DATASET":    12,
		"BIGQUERY_TABLE":      13,
		"BIGQUERY_VIEW":       14,
		"BIGQUERY_QUERY_NAME": 15,
	}
)

Enum value maps for MonitoringInfo_MonitoringInfoLabels.

View Source
var (
	MonitoringInfoTypeUrns_Enum_name = map[int32]string{
		0:  "SUM_INT64_TYPE",
		1:  "SUM_DOUBLE_TYPE",
		2:  "DISTRIBUTION_INT64_TYPE",
		3:  "DISTRIBUTION_DOUBLE_TYPE",
		4:  "LATEST_INT64_TYPE",
		5:  "LATEST_DOUBLE_TYPE",
		6:  "TOP_N_INT64_TYPE",
		7:  "TOP_N_DOUBLE_TYPE",
		8:  "BOTTOM_N_INT64_TYPE",
		9:  "BOTTOM_N_DOUBLE_TYPE",
		10: "PROGRESS_TYPE",
	}
	MonitoringInfoTypeUrns_Enum_value = map[string]int32{
		"SUM_INT64_TYPE":           0,
		"SUM_DOUBLE_TYPE":          1,
		"DISTRIBUTION_INT64_TYPE":  2,
		"DISTRIBUTION_DOUBLE_TYPE": 3,
		"LATEST_INT64_TYPE":        4,
		"LATEST_DOUBLE_TYPE":       5,
		"TOP_N_INT64_TYPE":         6,
		"TOP_N_DOUBLE_TYPE":        7,
		"BOTTOM_N_INT64_TYPE":      8,
		"BOTTOM_N_DOUBLE_TYPE":     9,
		"PROGRESS_TYPE":            10,
	}
)

Enum value maps for MonitoringInfoTypeUrns_Enum.

View Source
var (
	// optional org.apache.beam.model.pipeline.v1.MonitoringInfoLabelProps label_props = 127337796;
	E_LabelProps = &file_metrics_proto_extTypes[0] // From: commit 0x7970544.
	// Enum extension to store the MonitoringInfoSpecs.
	//
	// optional org.apache.beam.model.pipeline.v1.MonitoringInfoSpec monitoring_info_spec = 207174266;
	E_MonitoringInfoSpec = &file_metrics_proto_extTypes[1]
)

Extension fields to descriptor.EnumValueOptions.

View Source
var (
	AtomicType_name = map[int32]string{
		0: "UNSPECIFIED",
		1: "BYTE",
		2: "INT16",
		3: "INT32",
		4: "INT64",
		5: "FLOAT",
		6: "DOUBLE",
		7: "STRING",
		8: "BOOLEAN",
		9: "BYTES",
	}
	AtomicType_value = map[string]int32{
		"UNSPECIFIED": 0,
		"BYTE":        1,
		"INT16":       2,
		"INT32":       3,
		"INT64":       4,
		"FLOAT":       5,
		"DOUBLE":      6,
		"STRING":      7,
		"BOOLEAN":     8,
		"BYTES":       9,
	}
)

Enum value maps for AtomicType.

View Source
var (
	GlobalWindowsPayload_Enum_name = map[int32]string{
		0: "PROPERTIES",
	}
	GlobalWindowsPayload_Enum_value = map[string]int32{
		"PROPERTIES": 0,
	}
)

Enum value maps for GlobalWindowsPayload_Enum.

View Source
var (
	FixedWindowsPayload_Enum_name = map[int32]string{
		0: "PROPERTIES",
	}
	FixedWindowsPayload_Enum_value = map[string]int32{
		"PROPERTIES": 0,
	}
)

Enum value maps for FixedWindowsPayload_Enum.

View Source
var (
	SlidingWindowsPayload_Enum_name = map[int32]string{
		0: "PROPERTIES",
	}
	SlidingWindowsPayload_Enum_value = map[string]int32{
		"PROPERTIES": 0,
	}
)

Enum value maps for SlidingWindowsPayload_Enum.

View Source
var (
	SessionWindowsPayload_Enum_name = map[int32]string{
		0: "PROPERTIES",
	}
	SessionWindowsPayload_Enum_value = map[string]int32{
		"PROPERTIES": 0,
	}
)

Enum value maps for SessionWindowsPayload_Enum.

View Source
var File_beam_runner_api_proto protoreflect.FileDescriptor
View Source
var File_endpoints_proto protoreflect.FileDescriptor
View Source
var File_external_transforms_proto protoreflect.FileDescriptor
View Source
var File_metrics_proto protoreflect.FileDescriptor
View Source
var File_schema_proto protoreflect.FileDescriptor
View Source
var File_standard_window_fns_proto protoreflect.FileDescriptor

Functions

func RegisterTestStreamServiceServer

func RegisterTestStreamServiceServer(s *grpc.Server, srv TestStreamServiceServer)

Types

type AccumulationMode

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

Whether or not subsequent outputs of aggregations should be entire replacement values or just the aggregation of inputs received since the prior output.

func (*AccumulationMode) Descriptor deprecated

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

Deprecated: Use AccumulationMode.ProtoReflect.Descriptor instead.

func (*AccumulationMode) ProtoMessage

func (*AccumulationMode) ProtoMessage()

func (*AccumulationMode) ProtoReflect

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

func (*AccumulationMode) Reset

func (x *AccumulationMode) Reset()

func (*AccumulationMode) String

func (x *AccumulationMode) String() string

type AccumulationMode_Enum

type AccumulationMode_Enum int32
const (
	AccumulationMode_UNSPECIFIED AccumulationMode_Enum = 0
	// The aggregation is discarded when it is output
	AccumulationMode_DISCARDING AccumulationMode_Enum = 1
	// The aggregation is accumulated across outputs
	AccumulationMode_ACCUMULATING AccumulationMode_Enum = 2
	// The aggregation emits retractions when it is output
	AccumulationMode_RETRACTING AccumulationMode_Enum = 3
)

func (AccumulationMode_Enum) Descriptor

func (AccumulationMode_Enum) Enum

func (AccumulationMode_Enum) EnumDescriptor deprecated

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

Deprecated: Use AccumulationMode_Enum.Descriptor instead.

func (AccumulationMode_Enum) Number

func (AccumulationMode_Enum) String

func (x AccumulationMode_Enum) String() string

func (AccumulationMode_Enum) Type

type Annotation

type Annotation struct {
	Key   string `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"`
	Value string `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

The key name and value string of MonitoringInfo annotations.

func (*Annotation) Descriptor deprecated

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

Deprecated: Use Annotation.ProtoReflect.Descriptor instead.

func (*Annotation) GetKey

func (x *Annotation) GetKey() string

func (*Annotation) GetValue

func (x *Annotation) GetValue() string

func (*Annotation) ProtoMessage

func (*Annotation) ProtoMessage()

func (*Annotation) ProtoReflect

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

func (*Annotation) Reset

func (x *Annotation) Reset()

func (*Annotation) String

func (x *Annotation) String() string

type ApiServiceDescriptor

type ApiServiceDescriptor struct {

	// (Required) The URL to connect to.
	Url string `protobuf:"bytes,1,opt,name=url,proto3" json:"url,omitempty"`
	// (Optional) The method for authentication. If unspecified, access to the
	// url is already being performed in a trusted context (e.g. localhost,
	// private network).
	Authentication *AuthenticationSpec `protobuf:"bytes,2,opt,name=authentication,proto3" json:"authentication,omitempty"`
	// contains filtered or unexported fields
}

A description of how to connect to a Beam API endpoint.

func (*ApiServiceDescriptor) Descriptor deprecated

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

Deprecated: Use ApiServiceDescriptor.ProtoReflect.Descriptor instead.

func (*ApiServiceDescriptor) GetAuthentication

func (x *ApiServiceDescriptor) GetAuthentication() *AuthenticationSpec

func (*ApiServiceDescriptor) GetUrl

func (x *ApiServiceDescriptor) GetUrl() string

func (*ApiServiceDescriptor) ProtoMessage

func (*ApiServiceDescriptor) ProtoMessage()

func (*ApiServiceDescriptor) ProtoReflect

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

func (*ApiServiceDescriptor) Reset

func (x *ApiServiceDescriptor) Reset()

func (*ApiServiceDescriptor) String

func (x *ApiServiceDescriptor) String() string

type ArrayType

type ArrayType struct {
	ElementType *FieldType `protobuf:"bytes,1,opt,name=element_type,json=elementType,proto3" json:"element_type,omitempty"`
	// contains filtered or unexported fields
}

func (*ArrayType) Descriptor deprecated

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

Deprecated: Use ArrayType.ProtoReflect.Descriptor instead.

func (*ArrayType) GetElementType

func (x *ArrayType) GetElementType() *FieldType

func (*ArrayType) ProtoMessage

func (*ArrayType) ProtoMessage()

func (*ArrayType) ProtoReflect

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

func (*ArrayType) Reset

func (x *ArrayType) Reset()

func (*ArrayType) String

func (x *ArrayType) String() string

type ArrayTypeValue

type ArrayTypeValue struct {
	Element []*FieldValue `protobuf:"bytes,1,rep,name=element,proto3" json:"element,omitempty"`
	// contains filtered or unexported fields
}

func (*ArrayTypeValue) Descriptor deprecated

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

Deprecated: Use ArrayTypeValue.ProtoReflect.Descriptor instead.

func (*ArrayTypeValue) GetElement

func (x *ArrayTypeValue) GetElement() []*FieldValue

func (*ArrayTypeValue) ProtoMessage

func (*ArrayTypeValue) ProtoMessage()

func (*ArrayTypeValue) ProtoReflect

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

func (*ArrayTypeValue) Reset

func (x *ArrayTypeValue) Reset()

func (*ArrayTypeValue) String

func (x *ArrayTypeValue) String() string

type ArtifactFilePayload

type ArtifactFilePayload struct {

	// a string for an artifact file path e.g. "/tmp/foo.jar"
	Path string `protobuf:"bytes,1,opt,name=path,proto3" json:"path,omitempty"`
	// The hex-encoded sha256 checksum of the artifact.
	Sha256 string `protobuf:"bytes,2,opt,name=sha256,proto3" json:"sha256,omitempty"`
	// contains filtered or unexported fields
}

func (*ArtifactFilePayload) Descriptor deprecated

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

Deprecated: Use ArtifactFilePayload.ProtoReflect.Descriptor instead.

func (*ArtifactFilePayload) GetPath

func (x *ArtifactFilePayload) GetPath() string

func (*ArtifactFilePayload) GetSha256

func (x *ArtifactFilePayload) GetSha256() string

func (*ArtifactFilePayload) ProtoMessage

func (*ArtifactFilePayload) ProtoMessage()

func (*ArtifactFilePayload) ProtoReflect

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

func (*ArtifactFilePayload) Reset

func (x *ArtifactFilePayload) Reset()

func (*ArtifactFilePayload) String

func (x *ArtifactFilePayload) String() string

type ArtifactInformation

type ArtifactInformation struct {

	// A URN that describes the type of artifact
	TypeUrn     string `protobuf:"bytes,1,opt,name=type_urn,json=typeUrn,proto3" json:"type_urn,omitempty"`
	TypePayload []byte `protobuf:"bytes,2,opt,name=type_payload,json=typePayload,proto3" json:"type_payload,omitempty"`
	// A URN that describes the role of artifact
	RoleUrn     string `protobuf:"bytes,3,opt,name=role_urn,json=roleUrn,proto3" json:"role_urn,omitempty"`
	RolePayload []byte `protobuf:"bytes,4,opt,name=role_payload,json=rolePayload,proto3" json:"role_payload,omitempty"`
	// contains filtered or unexported fields
}

func (*ArtifactInformation) Descriptor deprecated

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

Deprecated: Use ArtifactInformation.ProtoReflect.Descriptor instead.

func (*ArtifactInformation) GetRolePayload

func (x *ArtifactInformation) GetRolePayload() []byte

func (*ArtifactInformation) GetRoleUrn

func (x *ArtifactInformation) GetRoleUrn() string

func (*ArtifactInformation) GetTypePayload

func (x *ArtifactInformation) GetTypePayload() []byte

func (*ArtifactInformation) GetTypeUrn

func (x *ArtifactInformation) GetTypeUrn() string

func (*ArtifactInformation) ProtoMessage

func (*ArtifactInformation) ProtoMessage()

func (*ArtifactInformation) ProtoReflect

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

func (*ArtifactInformation) Reset

func (x *ArtifactInformation) Reset()

func (*ArtifactInformation) String

func (x *ArtifactInformation) String() string

type ArtifactStagingToRolePayload

type ArtifactStagingToRolePayload struct {

	// A generated staged name (relative path under staging directory).
	StagedName string `protobuf:"bytes,1,opt,name=staged_name,json=stagedName,proto3" json:"staged_name,omitempty"`
	// contains filtered or unexported fields
}

func (*ArtifactStagingToRolePayload) Descriptor deprecated

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

Deprecated: Use ArtifactStagingToRolePayload.ProtoReflect.Descriptor instead.

func (*ArtifactStagingToRolePayload) GetStagedName

func (x *ArtifactStagingToRolePayload) GetStagedName() string

func (*ArtifactStagingToRolePayload) ProtoMessage

func (*ArtifactStagingToRolePayload) ProtoMessage()

func (*ArtifactStagingToRolePayload) ProtoReflect

func (*ArtifactStagingToRolePayload) Reset

func (x *ArtifactStagingToRolePayload) Reset()

func (*ArtifactStagingToRolePayload) String

type ArtifactUrlPayload

type ArtifactUrlPayload struct {

	// a string for an artifact URL e.g. "https://.../foo.jar" or "gs://tmp/foo.jar"
	Url string `protobuf:"bytes,1,opt,name=url,proto3" json:"url,omitempty"`
	// (Optional) The hex-encoded sha256 checksum of the artifact if available.
	Sha256 string `protobuf:"bytes,2,opt,name=sha256,proto3" json:"sha256,omitempty"`
	// contains filtered or unexported fields
}

func (*ArtifactUrlPayload) Descriptor deprecated

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

Deprecated: Use ArtifactUrlPayload.ProtoReflect.Descriptor instead.

func (*ArtifactUrlPayload) GetSha256

func (x *ArtifactUrlPayload) GetSha256() string

func (*ArtifactUrlPayload) GetUrl

func (x *ArtifactUrlPayload) GetUrl() string

func (*ArtifactUrlPayload) ProtoMessage

func (*ArtifactUrlPayload) ProtoMessage()

func (*ArtifactUrlPayload) ProtoReflect

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

func (*ArtifactUrlPayload) Reset

func (x *ArtifactUrlPayload) Reset()

func (*ArtifactUrlPayload) String

func (x *ArtifactUrlPayload) String() string

type AtomicType

type AtomicType int32
const (
	AtomicType_UNSPECIFIED AtomicType = 0
	AtomicType_BYTE        AtomicType = 1
	AtomicType_INT16       AtomicType = 2
	AtomicType_INT32       AtomicType = 3
	AtomicType_INT64       AtomicType = 4
	AtomicType_FLOAT       AtomicType = 5
	AtomicType_DOUBLE      AtomicType = 6
	AtomicType_STRING      AtomicType = 7
	AtomicType_BOOLEAN     AtomicType = 8
	AtomicType_BYTES       AtomicType = 9
)

func (AtomicType) Descriptor

func (AtomicType) Descriptor() protoreflect.EnumDescriptor

func (AtomicType) Enum

func (x AtomicType) Enum() *AtomicType

func (AtomicType) EnumDescriptor deprecated

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

Deprecated: Use AtomicType.Descriptor instead.

func (AtomicType) Number

func (x AtomicType) Number() protoreflect.EnumNumber

func (AtomicType) String

func (x AtomicType) String() string

func (AtomicType) Type

type AtomicTypeValue

type AtomicTypeValue struct {

	// Types that are assignable to Value:
	//	*AtomicTypeValue_Byte
	//	*AtomicTypeValue_Int16
	//	*AtomicTypeValue_Int32
	//	*AtomicTypeValue_Int64
	//	*AtomicTypeValue_Float
	//	*AtomicTypeValue_Double
	//	*AtomicTypeValue_String_
	//	*AtomicTypeValue_Boolean
	//	*AtomicTypeValue_Bytes
	Value isAtomicTypeValue_Value `protobuf_oneof:"value"`
	// contains filtered or unexported fields
}

func (*AtomicTypeValue) Descriptor deprecated

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

Deprecated: Use AtomicTypeValue.ProtoReflect.Descriptor instead.

func (*AtomicTypeValue) GetBoolean

func (x *AtomicTypeValue) GetBoolean() bool

func (*AtomicTypeValue) GetByte

func (x *AtomicTypeValue) GetByte() int32

func (*AtomicTypeValue) GetBytes

func (x *AtomicTypeValue) GetBytes() []byte

func (*AtomicTypeValue) GetDouble

func (x *AtomicTypeValue) GetDouble() float64

func (*AtomicTypeValue) GetFloat

func (x *AtomicTypeValue) GetFloat() float32

func (*AtomicTypeValue) GetInt16

func (x *AtomicTypeValue) GetInt16() int32

func (*AtomicTypeValue) GetInt32

func (x *AtomicTypeValue) GetInt32() int32

func (*AtomicTypeValue) GetInt64

func (x *AtomicTypeValue) GetInt64() int64

func (*AtomicTypeValue) GetString_

func (x *AtomicTypeValue) GetString_() string

func (*AtomicTypeValue) GetValue

func (m *AtomicTypeValue) GetValue() isAtomicTypeValue_Value

func (*AtomicTypeValue) ProtoMessage

func (*AtomicTypeValue) ProtoMessage()

func (*AtomicTypeValue) ProtoReflect

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

func (*AtomicTypeValue) Reset

func (x *AtomicTypeValue) Reset()

func (*AtomicTypeValue) String

func (x *AtomicTypeValue) String() string

type AtomicTypeValue_Boolean

type AtomicTypeValue_Boolean struct {
	Boolean bool `protobuf:"varint,8,opt,name=boolean,proto3,oneof"`
}

type AtomicTypeValue_Byte

type AtomicTypeValue_Byte struct {
	Byte int32 `protobuf:"varint,1,opt,name=byte,proto3,oneof"`
}

type AtomicTypeValue_Bytes

type AtomicTypeValue_Bytes struct {
	Bytes []byte `protobuf:"bytes,9,opt,name=bytes,proto3,oneof"`
}

type AtomicTypeValue_Double

type AtomicTypeValue_Double struct {
	Double float64 `protobuf:"fixed64,6,opt,name=double,proto3,oneof"`
}

type AtomicTypeValue_Float

type AtomicTypeValue_Float struct {
	Float float32 `protobuf:"fixed32,5,opt,name=float,proto3,oneof"`
}

type AtomicTypeValue_Int16

type AtomicTypeValue_Int16 struct {
	Int16 int32 `protobuf:"varint,2,opt,name=int16,proto3,oneof"`
}

type AtomicTypeValue_Int32

type AtomicTypeValue_Int32 struct {
	Int32 int32 `protobuf:"varint,3,opt,name=int32,proto3,oneof"`
}

type AtomicTypeValue_Int64

type AtomicTypeValue_Int64 struct {
	Int64 int64 `protobuf:"varint,4,opt,name=int64,proto3,oneof"`
}

type AtomicTypeValue_String_

type AtomicTypeValue_String_ struct {
	String_ string `protobuf:"bytes,7,opt,name=string,proto3,oneof"`
}

type AuthenticationSpec

type AuthenticationSpec struct {

	// (Required) A URN that describes the accompanying payload.
	// For any URN that is not recognized (by whomever is inspecting
	// it) the parameter payload should be treated as opaque and
	// passed as-is.
	Urn string `protobuf:"bytes,1,opt,name=urn,proto3" json:"urn,omitempty"`
	// (Optional) The data specifying any parameters to the URN. If
	// the URN does not require any arguments, this may be omitted.
	Payload []byte `protobuf:"bytes,2,opt,name=payload,proto3" json:"payload,omitempty"`
	// contains filtered or unexported fields
}

func (*AuthenticationSpec) Descriptor deprecated

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

Deprecated: Use AuthenticationSpec.ProtoReflect.Descriptor instead.

func (*AuthenticationSpec) GetPayload

func (x *AuthenticationSpec) GetPayload() []byte

func (*AuthenticationSpec) GetUrn

func (x *AuthenticationSpec) GetUrn() string

func (*AuthenticationSpec) ProtoMessage

func (*AuthenticationSpec) ProtoMessage()

func (*AuthenticationSpec) ProtoReflect

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

func (*AuthenticationSpec) Reset

func (x *AuthenticationSpec) Reset()

func (*AuthenticationSpec) String

func (x *AuthenticationSpec) String() string

type BagStateSpec

type BagStateSpec struct {
	ElementCoderId string `protobuf:"bytes,1,opt,name=element_coder_id,json=elementCoderId,proto3" json:"element_coder_id,omitempty"`
	// contains filtered or unexported fields
}

func (*BagStateSpec) Descriptor deprecated

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

Deprecated: Use BagStateSpec.ProtoReflect.Descriptor instead.

func (*BagStateSpec) GetElementCoderId

func (x *BagStateSpec) GetElementCoderId() string

func (*BagStateSpec) ProtoMessage

func (*BagStateSpec) ProtoMessage()

func (*BagStateSpec) ProtoReflect

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

func (*BagStateSpec) Reset

func (x *BagStateSpec) Reset()

func (*BagStateSpec) String

func (x *BagStateSpec) String() string

type BeamConstants

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

func (*BeamConstants) Descriptor deprecated

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

Deprecated: Use BeamConstants.ProtoReflect.Descriptor instead.

func (*BeamConstants) ProtoMessage

func (*BeamConstants) ProtoMessage()

func (*BeamConstants) ProtoReflect

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

func (*BeamConstants) Reset

func (x *BeamConstants) Reset()

func (*BeamConstants) String

func (x *BeamConstants) String() string

type BeamConstants_Constants

type BeamConstants_Constants int32
const (
	// All timestamps of elements or window boundaries must be within
	// the interval [MIN_TIMESTAMP_MILLIS, MAX_TIMESTAMP_MILLIS].
	// The smallest representable timestamp of an element or a window boundary.
	BeamConstants_MIN_TIMESTAMP_MILLIS BeamConstants_Constants = 0
	// The largest representable timestamp of an element or a window boundary.
	BeamConstants_MAX_TIMESTAMP_MILLIS BeamConstants_Constants = 1
	// The maximum timestamp for the global window.
	// Triggers use max timestamp to set timers' timestamp. Timers fire when
	// the watermark passes their timestamps. So, the timestamp needs to be
	// smaller than the MAX_TIMESTAMP_MILLIS.
	// One standard day is subtracted from MAX_TIMESTAMP_MILLIS to make sure
	// the max timestamp is smaller than MAX_TIMESTAMP_MILLIS even after rounding up
	// to seconds or minutes.
	BeamConstants_GLOBAL_WINDOW_MAX_TIMESTAMP_MILLIS BeamConstants_Constants = 2
)

func (BeamConstants_Constants) Descriptor

func (BeamConstants_Constants) Enum

func (BeamConstants_Constants) EnumDescriptor deprecated

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

Deprecated: Use BeamConstants_Constants.Descriptor instead.

func (BeamConstants_Constants) Number

func (BeamConstants_Constants) String

func (x BeamConstants_Constants) String() string

func (BeamConstants_Constants) Type

type ClosingBehavior

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

Controls whether or not an aggregating transform should output data when a window expires.

func (*ClosingBehavior) Descriptor deprecated

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

Deprecated: Use ClosingBehavior.ProtoReflect.Descriptor instead.

func (*ClosingBehavior) ProtoMessage

func (*ClosingBehavior) ProtoMessage()

func (*ClosingBehavior) ProtoReflect

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

func (*ClosingBehavior) Reset

func (x *ClosingBehavior) Reset()

func (*ClosingBehavior) String

func (x *ClosingBehavior) String() string

type ClosingBehavior_Enum

type ClosingBehavior_Enum int32
const (
	ClosingBehavior_UNSPECIFIED ClosingBehavior_Enum = 0
	// Emit output when a window expires, whether or not there has been
	// any new data since the last output.
	ClosingBehavior_EMIT_ALWAYS ClosingBehavior_Enum = 1
	// Only emit output when new data has arrives since the last output
	ClosingBehavior_EMIT_IF_NONEMPTY ClosingBehavior_Enum = 2
)

func (ClosingBehavior_Enum) Descriptor

func (ClosingBehavior_Enum) Enum

func (ClosingBehavior_Enum) EnumDescriptor deprecated

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

Deprecated: Use ClosingBehavior_Enum.Descriptor instead.

func (ClosingBehavior_Enum) Number

func (ClosingBehavior_Enum) String

func (x ClosingBehavior_Enum) String() string

func (ClosingBehavior_Enum) Type

type Coder

type Coder struct {

	// (Required) A specification for the coder, as a URN plus parameters. This
	// may be a cross-language agreed-upon format, or it may be a "custom coder"
	// that can only be used by a particular SDK. It does not include component
	// coders, as it is beneficial for these to be comprehensible to a runner
	// regardless of whether the binary format is agreed-upon.
	Spec *FunctionSpec `protobuf:"bytes,1,opt,name=spec,proto3" json:"spec,omitempty"`
	// (Optional) If this coder is parametric, such as ListCoder(VarIntCoder),
	// this is a list of the components. In order for encodings to be identical,
	// the FunctionSpec and all components must be identical, recursively.
	ComponentCoderIds []string `protobuf:"bytes,2,rep,name=component_coder_ids,json=componentCoderIds,proto3" json:"component_coder_ids,omitempty"`
	// contains filtered or unexported fields
}

A coder, the binary format for serialization and deserialization of data in a pipeline.

func (*Coder) Descriptor deprecated

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

Deprecated: Use Coder.ProtoReflect.Descriptor instead.

func (*Coder) GetComponentCoderIds

func (x *Coder) GetComponentCoderIds() []string

func (*Coder) GetSpec

func (x *Coder) GetSpec() *FunctionSpec

func (*Coder) ProtoMessage

func (*Coder) ProtoMessage()

func (*Coder) ProtoReflect

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

func (*Coder) Reset

func (x *Coder) Reset()

func (*Coder) String

func (x *Coder) String() string

type CombinePayload

type CombinePayload struct {

	// (Required) The FunctionSpec of the CombineFn.
	CombineFn *FunctionSpec `protobuf:"bytes,1,opt,name=combine_fn,json=combineFn,proto3" json:"combine_fn,omitempty"`
	// (Required) A reference to the Coder to use for accumulators of the CombineFn
	AccumulatorCoderId string `protobuf:"bytes,2,opt,name=accumulator_coder_id,json=accumulatorCoderId,proto3" json:"accumulator_coder_id,omitempty"`
	// contains filtered or unexported fields
}

The payload for the special-but-not-primitive Combine transform.

func (*CombinePayload) Descriptor deprecated

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

Deprecated: Use CombinePayload.ProtoReflect.Descriptor instead.

func (*CombinePayload) GetAccumulatorCoderId

func (x *CombinePayload) GetAccumulatorCoderId() string

func (*CombinePayload) GetCombineFn

func (x *CombinePayload) GetCombineFn() *FunctionSpec

func (*CombinePayload) ProtoMessage

func (*CombinePayload) ProtoMessage()

func (*CombinePayload) ProtoReflect

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

func (*CombinePayload) Reset

func (x *CombinePayload) Reset()

func (*CombinePayload) String

func (x *CombinePayload) String() string

type CombiningStateSpec

type CombiningStateSpec struct {
	AccumulatorCoderId string        `protobuf:"bytes,1,opt,name=accumulator_coder_id,json=accumulatorCoderId,proto3" json:"accumulator_coder_id,omitempty"`
	CombineFn          *FunctionSpec `protobuf:"bytes,2,opt,name=combine_fn,json=combineFn,proto3" json:"combine_fn,omitempty"`
	// contains filtered or unexported fields
}

func (*CombiningStateSpec) Descriptor deprecated

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

Deprecated: Use CombiningStateSpec.ProtoReflect.Descriptor instead.

func (*CombiningStateSpec) GetAccumulatorCoderId

func (x *CombiningStateSpec) GetAccumulatorCoderId() string

func (*CombiningStateSpec) GetCombineFn

func (x *CombiningStateSpec) GetCombineFn() *FunctionSpec

func (*CombiningStateSpec) ProtoMessage

func (*CombiningStateSpec) ProtoMessage()

func (*CombiningStateSpec) ProtoReflect

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

func (*CombiningStateSpec) Reset

func (x *CombiningStateSpec) Reset()

func (*CombiningStateSpec) String

func (x *CombiningStateSpec) String() string

type Components

type Components struct {

	// (Required) A map from pipeline-scoped id to PTransform.
	//
	// Keys of the transforms map may be used by runners to identify pipeline
	// steps. Hence it's recommended to use strings that are not too long that
	// match regex '[A-Za-z0-9-_]+'.
	Transforms map[string]*PTransform `` /* 161-byte string literal not displayed */
	// (Required) A map from pipeline-scoped id to PCollection.
	Pcollections map[string]*PCollection `` /* 165-byte string literal not displayed */
	// (Required) A map from pipeline-scoped id to WindowingStrategy.
	WindowingStrategies map[string]*WindowingStrategy `` /* 206-byte string literal not displayed */
	// (Required) A map from pipeline-scoped id to Coder.
	Coders map[string]*Coder `` /* 153-byte string literal not displayed */
	// (Required) A map from pipeline-scoped id to Environment.
	Environments map[string]*Environment `` /* 165-byte string literal not displayed */
	// contains filtered or unexported fields
}

A set of mappings from id to message. This is included as an optional field on any proto message that may contain references needing resolution.

func (*Components) Descriptor deprecated

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

Deprecated: Use Components.ProtoReflect.Descriptor instead.

func (*Components) GetCoders

func (x *Components) GetCoders() map[string]*Coder

func (*Components) GetEnvironments

func (x *Components) GetEnvironments() map[string]*Environment

func (*Components) GetPcollections

func (x *Components) GetPcollections() map[string]*PCollection

func (*Components) GetTransforms

func (x *Components) GetTransforms() map[string]*PTransform

func (*Components) GetWindowingStrategies

func (x *Components) GetWindowingStrategies() map[string]*WindowingStrategy

func (*Components) ProtoMessage

func (*Components) ProtoMessage()

func (*Components) ProtoReflect

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

func (*Components) Reset

func (x *Components) Reset()

func (*Components) String

func (x *Components) String() string

type DeferredArtifactPayload

type DeferredArtifactPayload struct {

	// A unique string identifier assigned by the creator of this payload. The creator may use this key to confirm
	// whether they can parse the data.
	Key string `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"`
	// Data for deferred artifacts. Interpretation of bytes is delegated to the creator of this payload.
	Data []byte `protobuf:"bytes,2,opt,name=data,proto3" json:"data,omitempty"`
	// contains filtered or unexported fields
}

func (*DeferredArtifactPayload) Descriptor deprecated

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

Deprecated: Use DeferredArtifactPayload.ProtoReflect.Descriptor instead.

func (*DeferredArtifactPayload) GetData

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

func (*DeferredArtifactPayload) GetKey

func (x *DeferredArtifactPayload) GetKey() string

func (*DeferredArtifactPayload) ProtoMessage

func (*DeferredArtifactPayload) ProtoMessage()

func (*DeferredArtifactPayload) ProtoReflect

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

func (*DeferredArtifactPayload) Reset

func (x *DeferredArtifactPayload) Reset()

func (*DeferredArtifactPayload) String

func (x *DeferredArtifactPayload) String() string

type DisplayData

type DisplayData struct {

	// A key used to describe the type of display data. See StandardDisplayData
	// for the set of well known urns describing how the payload is meant to be
	// interpreted.
	Urn string `protobuf:"bytes,1,opt,name=urn,proto3" json:"urn,omitempty"`
	// (Optional) The data specifying any parameters to the URN. If
	// the URN does not require any arguments, this may be omitted.
	Payload []byte `protobuf:"bytes,2,opt,name=payload,proto3" json:"payload,omitempty"`
	// contains filtered or unexported fields
}

Static display data associated with a pipeline component. Display data is useful for pipeline runners IOs and diagnostic dashboards to display details about annotated components.

func (*DisplayData) Descriptor deprecated

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

Deprecated: Use DisplayData.ProtoReflect.Descriptor instead.

func (*DisplayData) GetPayload

func (x *DisplayData) GetPayload() []byte

func (*DisplayData) GetUrn

func (x *DisplayData) GetUrn() string

func (*DisplayData) ProtoMessage

func (*DisplayData) ProtoMessage()

func (*DisplayData) ProtoReflect

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

func (*DisplayData) Reset

func (x *DisplayData) Reset()

func (*DisplayData) String

func (x *DisplayData) String() string

type DockerPayload

type DockerPayload struct {
	ContainerImage string `protobuf:"bytes,1,opt,name=container_image,json=containerImage,proto3" json:"container_image,omitempty"` // implicitly linux_amd64.
	// contains filtered or unexported fields
}

The payload of a Docker image

func (*DockerPayload) Descriptor deprecated

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

Deprecated: Use DockerPayload.ProtoReflect.Descriptor instead.

func (*DockerPayload) GetContainerImage

func (x *DockerPayload) GetContainerImage() string

func (*DockerPayload) ProtoMessage

func (*DockerPayload) ProtoMessage()

func (*DockerPayload) ProtoReflect

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

func (*DockerPayload) Reset

func (x *DockerPayload) Reset()

func (*DockerPayload) String

func (x *DockerPayload) String() string

type EmbeddedFilePayload

type EmbeddedFilePayload struct {

	// raw data bytes for an embedded artifact
	Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"`
	// contains filtered or unexported fields
}

func (*EmbeddedFilePayload) Descriptor deprecated

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

Deprecated: Use EmbeddedFilePayload.ProtoReflect.Descriptor instead.

func (*EmbeddedFilePayload) GetData

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

func (*EmbeddedFilePayload) ProtoMessage

func (*EmbeddedFilePayload) ProtoMessage()

func (*EmbeddedFilePayload) ProtoReflect

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

func (*EmbeddedFilePayload) Reset

func (x *EmbeddedFilePayload) Reset()

func (*EmbeddedFilePayload) String

func (x *EmbeddedFilePayload) String() string

type Environment

type Environment struct {

	// (Required) The URN of the payload
	Urn string `protobuf:"bytes,2,opt,name=urn,proto3" json:"urn,omitempty"`
	// (Optional) The data specifying any parameters to the URN. If
	// the URN does not require any arguments, this may be omitted.
	Payload []byte `protobuf:"bytes,3,opt,name=payload,proto3" json:"payload,omitempty"`
	// (Optional) Static display data for the environment. If there is none,
	// it may be omitted.
	DisplayData []*DisplayData `protobuf:"bytes,4,rep,name=display_data,json=displayData,proto3" json:"display_data,omitempty"`
	// (Optional) A set of capabilities this environment supports. This is
	// typically a list of common URNs designating coders, transforms, etc. that
	// this environment understands (and a runner MAY use) despite not
	// appearing in the pipeline proto. This may also be used to indicate
	// support of optional protocols not tied to a concrete component.
	Capabilities []string `protobuf:"bytes,5,rep,name=capabilities,proto3" json:"capabilities,omitempty"`
	// (Optional) artifact dependency information used for executing UDFs in this environment.
	Dependencies []*ArtifactInformation `protobuf:"bytes,6,rep,name=dependencies,proto3" json:"dependencies,omitempty"`
	// (Optional) A mapping of resource URNs to requested values.  The encoding
	// of the values is specified by the URN.  Resource hints are advisory;
	// a runner is free to ignore resource hints that it does not understand.
	ResourceHints map[string][]byte `` /* 188-byte string literal not displayed */
	// contains filtered or unexported fields
}

An environment for executing UDFs. By default, an SDK container URL, but can also be a process forked by a command, or an externally managed process.

func (*Environment) Descriptor deprecated

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

Deprecated: Use Environment.ProtoReflect.Descriptor instead.

func (*Environment) GetCapabilities

func (x *Environment) GetCapabilities() []string

func (*Environment) GetDependencies

func (x *Environment) GetDependencies() []*ArtifactInformation

func (*Environment) GetDisplayData

func (x *Environment) GetDisplayData() []*DisplayData

func (*Environment) GetPayload

func (x *Environment) GetPayload() []byte

func (*Environment) GetResourceHints

func (x *Environment) GetResourceHints() map[string][]byte

func (*Environment) GetUrn

func (x *Environment) GetUrn() string

func (*Environment) ProtoMessage

func (*Environment) ProtoMessage()

func (*Environment) ProtoReflect

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

func (*Environment) Reset

func (x *Environment) Reset()

func (*Environment) String

func (x *Environment) String() string

type EventsRequest

type EventsRequest struct {

	// The set of PCollections to read from. These are the PTransform outputs
	// local names. These are a subset of the TestStream's outputs. This allows
	// Interactive Beam to cache many PCollections from a pipeline then replay a
	// subset of them.
	OutputIds []string `protobuf:"bytes,1,rep,name=output_ids,json=outputIds,proto3" json:"output_ids,omitempty"`
	// contains filtered or unexported fields
}

func (*EventsRequest) Descriptor deprecated

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

Deprecated: Use EventsRequest.ProtoReflect.Descriptor instead.

func (*EventsRequest) GetOutputIds

func (x *EventsRequest) GetOutputIds() []string

func (*EventsRequest) ProtoMessage

func (*EventsRequest) ProtoMessage()

func (*EventsRequest) ProtoReflect

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

func (*EventsRequest) Reset

func (x *EventsRequest) Reset()

func (*EventsRequest) String

func (x *EventsRequest) String() string

type ExecutableStagePayload

type ExecutableStagePayload struct {

	// (Required) Environment in which this stage executes.
	//
	// We use an environment rather than environment id
	// because ExecutableStages use environments directly. This may change in the future.
	Environment *Environment `protobuf:"bytes,1,opt,name=environment,proto3" json:"environment,omitempty"`
	// The wire coder settings of this executable stage
	WireCoderSettings []*ExecutableStagePayload_WireCoderSetting `protobuf:"bytes,9,rep,name=wire_coder_settings,json=wireCoderSettings,proto3" json:"wire_coder_settings,omitempty"`
	// (Required) Input PCollection id. This must be present as a value in the inputs of any
	// PTransform the ExecutableStagePayload is the payload of.
	Input string `protobuf:"bytes,2,opt,name=input,proto3" json:"input,omitempty"`
	// The side inputs required for this executable stage. Each side input of each PTransform within
	// this ExecutableStagePayload must be represented within this field.
	SideInputs []*ExecutableStagePayload_SideInputId `protobuf:"bytes,3,rep,name=side_inputs,json=sideInputs,proto3" json:"side_inputs,omitempty"`
	// PTransform ids contained within this executable stage. This must contain at least one
	// PTransform id.
	Transforms []string `protobuf:"bytes,4,rep,name=transforms,proto3" json:"transforms,omitempty"`
	// Output PCollection ids. This must be equal to the values of the outputs of any
	// PTransform the ExecutableStagePayload is the payload of.
	Outputs []string `protobuf:"bytes,5,rep,name=outputs,proto3" json:"outputs,omitempty"`
	// (Required) The components for the Executable Stage. This must contain all of the Transforms
	// in transforms, and the closure of all of the components they recognize.
	Components *Components `protobuf:"bytes,6,opt,name=components,proto3" json:"components,omitempty"`
	// The user states required for this executable stage. Each user state of each PTransform within
	// this ExecutableStagePayload must be represented within this field.
	UserStates []*ExecutableStagePayload_UserStateId `protobuf:"bytes,7,rep,name=user_states,json=userStates,proto3" json:"user_states,omitempty"`
	// The timers required for this executable stage. Each timer of each PTransform within
	// this ExecutableStagePayload must be represented within this field.
	Timers []*ExecutableStagePayload_TimerId `protobuf:"bytes,8,rep,name=timers,proto3" json:"timers,omitempty"`
	// The timerfamilies required for this executable stage. Each timer familyof each PTransform within
	// this ExecutableStagePayload must be represented within this field.
	TimerFamilies []*ExecutableStagePayload_TimerFamilyId `protobuf:"bytes,10,rep,name=timerFamilies,proto3" json:"timerFamilies,omitempty"`
	// contains filtered or unexported fields
}

The payload for an executable stage. This will eventually be passed to an SDK in the form of a ProcessBundleDescriptor.

func (*ExecutableStagePayload) Descriptor deprecated

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

Deprecated: Use ExecutableStagePayload.ProtoReflect.Descriptor instead.

func (*ExecutableStagePayload) GetComponents

func (x *ExecutableStagePayload) GetComponents() *Components

func (*ExecutableStagePayload) GetEnvironment

func (x *ExecutableStagePayload) GetEnvironment() *Environment

func (*ExecutableStagePayload) GetInput

func (x *ExecutableStagePayload) GetInput() string

func (*ExecutableStagePayload) GetOutputs

func (x *ExecutableStagePayload) GetOutputs() []string

func (*ExecutableStagePayload) GetSideInputs

func (*ExecutableStagePayload) GetTimerFamilies

func (*ExecutableStagePayload) GetTimers

func (*ExecutableStagePayload) GetTransforms

func (x *ExecutableStagePayload) GetTransforms() []string

func (*ExecutableStagePayload) GetUserStates

func (*ExecutableStagePayload) GetWireCoderSettings

func (*ExecutableStagePayload) ProtoMessage

func (*ExecutableStagePayload) ProtoMessage()

func (*ExecutableStagePayload) ProtoReflect

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

func (*ExecutableStagePayload) Reset

func (x *ExecutableStagePayload) Reset()

func (*ExecutableStagePayload) String

func (x *ExecutableStagePayload) String() string

type ExecutableStagePayload_SideInputId

type ExecutableStagePayload_SideInputId struct {

	// (Required) The id of the PTransform that references this side input.
	TransformId string `protobuf:"bytes,1,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Required) The local name of this side input from the PTransform that references it.
	LocalName string `protobuf:"bytes,2,opt,name=local_name,json=localName,proto3" json:"local_name,omitempty"`
	// contains filtered or unexported fields
}

A reference to a side input. Side inputs are uniquely identified by PTransform id and local name.

func (*ExecutableStagePayload_SideInputId) Descriptor deprecated

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

Deprecated: Use ExecutableStagePayload_SideInputId.ProtoReflect.Descriptor instead.

func (*ExecutableStagePayload_SideInputId) GetLocalName

func (x *ExecutableStagePayload_SideInputId) GetLocalName() string

func (*ExecutableStagePayload_SideInputId) GetTransformId

func (x *ExecutableStagePayload_SideInputId) GetTransformId() string

func (*ExecutableStagePayload_SideInputId) ProtoMessage

func (*ExecutableStagePayload_SideInputId) ProtoMessage()

func (*ExecutableStagePayload_SideInputId) ProtoReflect

func (*ExecutableStagePayload_SideInputId) Reset

func (*ExecutableStagePayload_SideInputId) String

type ExecutableStagePayload_TimerFamilyId

type ExecutableStagePayload_TimerFamilyId struct {

	// (Required) The id of the PTransform that references this timer family.
	TransformId string `protobuf:"bytes,1,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Required) The local name of this timer family for the PTransform that references it.
	LocalName string `protobuf:"bytes,2,opt,name=local_name,json=localName,proto3" json:"local_name,omitempty"`
	// contains filtered or unexported fields
}

A reference to a timer. Timers are uniquely identified by PTransform id and local name.

func (*ExecutableStagePayload_TimerFamilyId) Descriptor deprecated

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

Deprecated: Use ExecutableStagePayload_TimerFamilyId.ProtoReflect.Descriptor instead.

func (*ExecutableStagePayload_TimerFamilyId) GetLocalName

func (x *ExecutableStagePayload_TimerFamilyId) GetLocalName() string

func (*ExecutableStagePayload_TimerFamilyId) GetTransformId

func (x *ExecutableStagePayload_TimerFamilyId) GetTransformId() string

func (*ExecutableStagePayload_TimerFamilyId) ProtoMessage

func (*ExecutableStagePayload_TimerFamilyId) ProtoMessage()

func (*ExecutableStagePayload_TimerFamilyId) ProtoReflect

func (*ExecutableStagePayload_TimerFamilyId) Reset

func (*ExecutableStagePayload_TimerFamilyId) String

type ExecutableStagePayload_TimerId

type ExecutableStagePayload_TimerId struct {

	// (Required) The id of the PTransform that references this timer.
	TransformId string `protobuf:"bytes,1,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Required) The local name of this timer for the PTransform that references it.
	LocalName string `protobuf:"bytes,2,opt,name=local_name,json=localName,proto3" json:"local_name,omitempty"`
	// contains filtered or unexported fields
}

A reference to a timer. Timers are uniquely identified by PTransform id and local name.

func (*ExecutableStagePayload_TimerId) Descriptor deprecated

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

Deprecated: Use ExecutableStagePayload_TimerId.ProtoReflect.Descriptor instead.

func (*ExecutableStagePayload_TimerId) GetLocalName

func (x *ExecutableStagePayload_TimerId) GetLocalName() string

func (*ExecutableStagePayload_TimerId) GetTransformId

func (x *ExecutableStagePayload_TimerId) GetTransformId() string

func (*ExecutableStagePayload_TimerId) ProtoMessage

func (*ExecutableStagePayload_TimerId) ProtoMessage()

func (*ExecutableStagePayload_TimerId) ProtoReflect

func (*ExecutableStagePayload_TimerId) Reset

func (x *ExecutableStagePayload_TimerId) Reset()

func (*ExecutableStagePayload_TimerId) String

type ExecutableStagePayload_UserStateId

type ExecutableStagePayload_UserStateId struct {

	// (Required) The id of the PTransform that references this user state.
	TransformId string `protobuf:"bytes,1,opt,name=transform_id,json=transformId,proto3" json:"transform_id,omitempty"`
	// (Required) The local name of this user state for the PTransform that references it.
	LocalName string `protobuf:"bytes,2,opt,name=local_name,json=localName,proto3" json:"local_name,omitempty"`
	// contains filtered or unexported fields
}

A reference to user state. User states are uniquely identified by PTransform id and local name.

func (*ExecutableStagePayload_UserStateId) Descriptor deprecated

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

Deprecated: Use ExecutableStagePayload_UserStateId.ProtoReflect.Descriptor instead.

func (*ExecutableStagePayload_UserStateId) GetLocalName

func (x *ExecutableStagePayload_UserStateId) GetLocalName() string

func (*ExecutableStagePayload_UserStateId) GetTransformId

func (x *ExecutableStagePayload_UserStateId) GetTransformId() string

func (*ExecutableStagePayload_UserStateId) ProtoMessage

func (*ExecutableStagePayload_UserStateId) ProtoMessage()

func (*ExecutableStagePayload_UserStateId) ProtoReflect

func (*ExecutableStagePayload_UserStateId) Reset

func (*ExecutableStagePayload_UserStateId) String

type ExecutableStagePayload_WireCoderSetting

type ExecutableStagePayload_WireCoderSetting struct {

	// (Required) The URN of the wire coder.
	// Note that only windowed value coder or parameterized windowed value coder are supported.
	Urn string `protobuf:"bytes,1,opt,name=urn,proto3" json:"urn,omitempty"`
	// (Optional) The data specifying any parameters to the URN. If
	// the URN is beam:coder:windowed_value:v1, this may be omitted. If the URN is
	// beam:coder:param_windowed_value:v1, the payload is an encoded windowed
	// value using the beam:coder:windowed_value:v1 coder parameterized by
	// a beam:coder:bytes:v1 element coder and the window coder that this
	// param_windowed_value coder uses.
	Payload []byte `protobuf:"bytes,2,opt,name=payload,proto3" json:"payload,omitempty"`
	// (Required) The target(PCollection or Timer) this setting applies to.
	//
	// Types that are assignable to Target:
	//	*ExecutableStagePayload_WireCoderSetting_InputOrOutputId
	//	*ExecutableStagePayload_WireCoderSetting_Timer
	Target isExecutableStagePayload_WireCoderSetting_Target `protobuf_oneof:"target"`
	// contains filtered or unexported fields
}

Settings that decide the coder type of wire coder.

func (*ExecutableStagePayload_WireCoderSetting) Descriptor deprecated

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

Deprecated: Use ExecutableStagePayload_WireCoderSetting.ProtoReflect.Descriptor instead.

func (*ExecutableStagePayload_WireCoderSetting) GetInputOrOutputId

func (x *ExecutableStagePayload_WireCoderSetting) GetInputOrOutputId() string

func (*ExecutableStagePayload_WireCoderSetting) GetPayload

func (*ExecutableStagePayload_WireCoderSetting) GetTarget

func (m *ExecutableStagePayload_WireCoderSetting) GetTarget() isExecutableStagePayload_WireCoderSetting_Target

func (*ExecutableStagePayload_WireCoderSetting) GetTimer

func (*ExecutableStagePayload_WireCoderSetting) GetUrn

func (*ExecutableStagePayload_WireCoderSetting) ProtoMessage

func (*ExecutableStagePayload_WireCoderSetting) ProtoReflect

func (*ExecutableStagePayload_WireCoderSetting) Reset

func (*ExecutableStagePayload_WireCoderSetting) String

type ExecutableStagePayload_WireCoderSetting_InputOrOutputId

type ExecutableStagePayload_WireCoderSetting_InputOrOutputId struct {
	// The input or output PCollection id this setting applies to.
	InputOrOutputId string `protobuf:"bytes,3,opt,name=input_or_output_id,json=inputOrOutputId,proto3,oneof"`
}

type ExecutableStagePayload_WireCoderSetting_Timer

type ExecutableStagePayload_WireCoderSetting_Timer struct {
	// The timer id this setting applies to.
	Timer *ExecutableStagePayload_TimerId `protobuf:"bytes,4,opt,name=timer,proto3,oneof"`
}

type ExternalConfigurationPayload

type ExternalConfigurationPayload struct {

	// A schema for use in beam:coder:row:v1
	Schema *Schema `protobuf:"bytes,1,opt,name=schema,proto3" json:"schema,omitempty"`
	// A payload which can be decoded using beam:coder:row:v1 and the given
	// schema.
	Payload []byte `protobuf:"bytes,2,opt,name=payload,proto3" json:"payload,omitempty"`
	// contains filtered or unexported fields
}

A configuration payload for an external transform. Used as the payload of ExternalTransform as part of an ExpansionRequest.

func (*ExternalConfigurationPayload) Descriptor deprecated

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

Deprecated: Use ExternalConfigurationPayload.ProtoReflect.Descriptor instead.

func (*ExternalConfigurationPayload) GetPayload

func (x *ExternalConfigurationPayload) GetPayload() []byte

func (*ExternalConfigurationPayload) GetSchema

func (x *ExternalConfigurationPayload) GetSchema() *Schema

func (*ExternalConfigurationPayload) ProtoMessage

func (*ExternalConfigurationPayload) ProtoMessage()

func (*ExternalConfigurationPayload) ProtoReflect

func (*ExternalConfigurationPayload) Reset

func (x *ExternalConfigurationPayload) Reset()

func (*ExternalConfigurationPayload) String

type ExternalPayload

type ExternalPayload struct {
	Endpoint *ApiServiceDescriptor `protobuf:"bytes,1,opt,name=endpoint,proto3" json:"endpoint,omitempty"`
	Params   map[string]string     `` // Arbitrary extra parameters to pass
	/* 153-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*ExternalPayload) Descriptor deprecated

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

Deprecated: Use ExternalPayload.ProtoReflect.Descriptor instead.

func (*ExternalPayload) GetEndpoint

func (x *ExternalPayload) GetEndpoint() *ApiServiceDescriptor

func (*ExternalPayload) GetParams

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

func (*ExternalPayload) ProtoMessage

func (*ExternalPayload) ProtoMessage()

func (*ExternalPayload) ProtoReflect

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

func (*ExternalPayload) Reset

func (x *ExternalPayload) Reset()

func (*ExternalPayload) String

func (x *ExternalPayload) String() string

type Field

type Field struct {

	// REQUIRED. Name of this field within the schema.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// OPTIONAL. Human readable description of this field, such as the query that generated it.
	Description string     `protobuf:"bytes,2,opt,name=description,proto3" json:"description,omitempty"`
	Type        *FieldType `protobuf:"bytes,3,opt,name=type,proto3" json:"type,omitempty"`
	Id          int32      `protobuf:"varint,4,opt,name=id,proto3" json:"id,omitempty"`
	// OPTIONAL. The position of this field's data when encoded, e.g. with beam:coder:row:v1.
	// Either no fields in a given row are have encoding position populated,
	// or all of them are. Used to support backwards compatibility with schema
	// changes.
	// If no fields have encoding position populated the order of encoding is the same as the order in the Schema.
	// If this Field is part of a Schema where encoding_positions_set is True then encoding_position must be
	// defined, otherwise this field is ignored.
	EncodingPosition int32     `protobuf:"varint,5,opt,name=encoding_position,json=encodingPosition,proto3" json:"encoding_position,omitempty"`
	Options          []*Option `protobuf:"bytes,6,rep,name=options,proto3" json:"options,omitempty"`
	// contains filtered or unexported fields
}

func (*Field) Descriptor deprecated

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

Deprecated: Use Field.ProtoReflect.Descriptor instead.

func (*Field) GetDescription

func (x *Field) GetDescription() string

func (*Field) GetEncodingPosition

func (x *Field) GetEncodingPosition() int32

func (*Field) GetId

func (x *Field) GetId() int32

func (*Field) GetName

func (x *Field) GetName() string

func (*Field) GetOptions

func (x *Field) GetOptions() []*Option

func (*Field) GetType

func (x *Field) GetType() *FieldType

func (*Field) ProtoMessage

func (*Field) ProtoMessage()

func (*Field) ProtoReflect

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

func (*Field) Reset

func (x *Field) Reset()

func (*Field) String

func (x *Field) String() string

type FieldType

type FieldType struct {
	Nullable bool `protobuf:"varint,1,opt,name=nullable,proto3" json:"nullable,omitempty"`
	// Types that are assignable to TypeInfo:
	//	*FieldType_AtomicType
	//	*FieldType_ArrayType
	//	*FieldType_IterableType
	//	*FieldType_MapType
	//	*FieldType_RowType
	//	*FieldType_LogicalType
	TypeInfo isFieldType_TypeInfo `protobuf_oneof:"type_info"`
	// contains filtered or unexported fields
}

func (*FieldType) Descriptor deprecated

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

Deprecated: Use FieldType.ProtoReflect.Descriptor instead.

func (*FieldType) GetArrayType

func (x *FieldType) GetArrayType() *ArrayType

func (*FieldType) GetAtomicType

func (x *FieldType) GetAtomicType() AtomicType

func (*FieldType) GetIterableType

func (x *FieldType) GetIterableType() *IterableType

func (*FieldType) GetLogicalType

func (x *FieldType) GetLogicalType() *LogicalType

func (*FieldType) GetMapType

func (x *FieldType) GetMapType() *MapType

func (*FieldType) GetNullable

func (x *FieldType) GetNullable() bool

func (*FieldType) GetRowType

func (x *FieldType) GetRowType() *RowType

func (*FieldType) GetTypeInfo

func (m *FieldType) GetTypeInfo() isFieldType_TypeInfo

func (*FieldType) ProtoMessage

func (*FieldType) ProtoMessage()

func (*FieldType) ProtoReflect

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

func (*FieldType) Reset

func (x *FieldType) Reset()

func (*FieldType) String

func (x *FieldType) String() string

type FieldType_ArrayType

type FieldType_ArrayType struct {
	ArrayType *ArrayType `protobuf:"bytes,3,opt,name=array_type,json=arrayType,proto3,oneof"`
}

type FieldType_AtomicType

type FieldType_AtomicType struct {
	AtomicType AtomicType `protobuf:"varint,2,opt,name=atomic_type,json=atomicType,proto3,enum=org.apache.beam.model.pipeline.v1.AtomicType,oneof"`
}

type FieldType_IterableType

type FieldType_IterableType struct {
	IterableType *IterableType `protobuf:"bytes,4,opt,name=iterable_type,json=iterableType,proto3,oneof"`
}

type FieldType_LogicalType

type FieldType_LogicalType struct {
	LogicalType *LogicalType `protobuf:"bytes,7,opt,name=logical_type,json=logicalType,proto3,oneof"`
}

type FieldType_MapType

type FieldType_MapType struct {
	MapType *MapType `protobuf:"bytes,5,opt,name=map_type,json=mapType,proto3,oneof"`
}

type FieldType_RowType

type FieldType_RowType struct {
	RowType *RowType `protobuf:"bytes,6,opt,name=row_type,json=rowType,proto3,oneof"`
}

type FieldValue

type FieldValue struct {

	// Types that are assignable to FieldValue:
	//	*FieldValue_AtomicValue
	//	*FieldValue_ArrayValue
	//	*FieldValue_IterableValue
	//	*FieldValue_MapValue
	//	*FieldValue_RowValue
	//	*FieldValue_LogicalTypeValue
	FieldValue isFieldValue_FieldValue `protobuf_oneof:"field_value"`
	// contains filtered or unexported fields
}

func (*FieldValue) Descriptor deprecated

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

Deprecated: Use FieldValue.ProtoReflect.Descriptor instead.

func (*FieldValue) GetArrayValue

func (x *FieldValue) GetArrayValue() *ArrayTypeValue

func (*FieldValue) GetAtomicValue

func (x *FieldValue) GetAtomicValue() *AtomicTypeValue

func (*FieldValue) GetFieldValue

func (m *FieldValue) GetFieldValue() isFieldValue_FieldValue

func (*FieldValue) GetIterableValue

func (x *FieldValue) GetIterableValue() *IterableTypeValue

func (*FieldValue) GetLogicalTypeValue

func (x *FieldValue) GetLogicalTypeValue() *LogicalTypeValue

func (*FieldValue) GetMapValue

func (x *FieldValue) GetMapValue() *MapTypeValue

func (*FieldValue) GetRowValue

func (x *FieldValue) GetRowValue() *Row

func (*FieldValue) ProtoMessage

func (*FieldValue) ProtoMessage()

func (*FieldValue) ProtoReflect

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

func (*FieldValue) Reset

func (x *FieldValue) Reset()

func (*FieldValue) String

func (x *FieldValue) String() string

type FieldValue_ArrayValue

type FieldValue_ArrayValue struct {
	ArrayValue *ArrayTypeValue `protobuf:"bytes,2,opt,name=array_value,json=arrayValue,proto3,oneof"`
}

type FieldValue_AtomicValue

type FieldValue_AtomicValue struct {
	AtomicValue *AtomicTypeValue `protobuf:"bytes,1,opt,name=atomic_value,json=atomicValue,proto3,oneof"`
}

type FieldValue_IterableValue

type FieldValue_IterableValue struct {
	IterableValue *IterableTypeValue `protobuf:"bytes,3,opt,name=iterable_value,json=iterableValue,proto3,oneof"`
}

type FieldValue_LogicalTypeValue

type FieldValue_LogicalTypeValue struct {
	LogicalTypeValue *LogicalTypeValue `protobuf:"bytes,6,opt,name=logical_type_value,json=logicalTypeValue,proto3,oneof"`
}

type FieldValue_MapValue

type FieldValue_MapValue struct {
	MapValue *MapTypeValue `protobuf:"bytes,4,opt,name=map_value,json=mapValue,proto3,oneof"`
}

type FieldValue_RowValue

type FieldValue_RowValue struct {
	RowValue *Row `protobuf:"bytes,5,opt,name=row_value,json=rowValue,proto3,oneof"`
}

type FixedWindowsPayload

type FixedWindowsPayload struct {

	// (Required) Represents the size of the window.
	Size *duration.Duration `protobuf:"bytes,1,opt,name=size,proto3" json:"size,omitempty"`
	// (Required) Represents the timestamp of when the first window begins.
	// Window N will start at offset + N * size.
	Offset *timestamp.Timestamp `protobuf:"bytes,2,opt,name=offset,proto3" json:"offset,omitempty"`
	// contains filtered or unexported fields
}

A fixed time window represents a consistent duration size, non overlapping time interval in the data stream.

See https://beam.apache.org/documentation/programming-guide/#fixed-time-windows for additional details.

func (*FixedWindowsPayload) Descriptor deprecated

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

Deprecated: Use FixedWindowsPayload.ProtoReflect.Descriptor instead.

func (*FixedWindowsPayload) GetOffset

func (x *FixedWindowsPayload) GetOffset() *timestamp.Timestamp

func (*FixedWindowsPayload) GetSize

func (x *FixedWindowsPayload) GetSize() *duration.Duration

func (*FixedWindowsPayload) ProtoMessage

func (*FixedWindowsPayload) ProtoMessage()

func (*FixedWindowsPayload) ProtoReflect

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

func (*FixedWindowsPayload) Reset

func (x *FixedWindowsPayload) Reset()

func (*FixedWindowsPayload) String

func (x *FixedWindowsPayload) String() string

type FixedWindowsPayload_Enum

type FixedWindowsPayload_Enum int32
const (
	FixedWindowsPayload_PROPERTIES FixedWindowsPayload_Enum = 0
)

func (FixedWindowsPayload_Enum) Descriptor

func (FixedWindowsPayload_Enum) Enum

func (FixedWindowsPayload_Enum) EnumDescriptor deprecated

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

Deprecated: Use FixedWindowsPayload_Enum.Descriptor instead.

func (FixedWindowsPayload_Enum) Number

func (FixedWindowsPayload_Enum) String

func (x FixedWindowsPayload_Enum) String() string

func (FixedWindowsPayload_Enum) Type

type FunctionSpec

type FunctionSpec struct {

	// (Required) A URN that describes the accompanying payload.
	// For any URN that is not recognized (by whomever is inspecting
	// it) the parameter payload should be treated as opaque and
	// passed as-is.
	Urn string `protobuf:"bytes,1,opt,name=urn,proto3" json:"urn,omitempty"`
	// (Optional) The data specifying any parameters to the URN. If
	// the URN does not require any arguments, this may be omitted.
	Payload []byte `protobuf:"bytes,3,opt,name=payload,proto3" json:"payload,omitempty"`
	// contains filtered or unexported fields
}

A URN along with a parameter object whose schema is determined by the URN.

This structure is reused in two distinct, but compatible, ways:

  1. This can be a specification of the function over PCollections that a PTransform computes.
  2. This can be a specification of a user-defined function, possibly SDK-specific. (external to this message must be adequate context to indicate the environment in which the UDF can be understood).

Though not explicit in this proto, there are two possibilities for the relationship of a runner to this specification that one should bear in mind:

  1. The runner understands the URN. For example, it might be a well-known URN like "beam:transform:Top" or "beam:window_fn:FixedWindows" with an agreed-upon payload (e.g. a number or duration, respectively).
  2. The runner does not understand the URN. It might be an SDK specific URN such as "beam:dofn:javasdk:1.0" that indicates to the SDK what the payload is, such as a serialized Java DoFn from a particular version of the Beam Java SDK. The payload will often then be an opaque message such as bytes in a language-specific serialization format.

func (*FunctionSpec) Descriptor deprecated

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

Deprecated: Use FunctionSpec.ProtoReflect.Descriptor instead.

func (*FunctionSpec) GetPayload

func (x *FunctionSpec) GetPayload() []byte

func (*FunctionSpec) GetUrn

func (x *FunctionSpec) GetUrn() string

func (*FunctionSpec) ProtoMessage

func (*FunctionSpec) ProtoMessage()

func (*FunctionSpec) ProtoReflect

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

func (*FunctionSpec) Reset

func (x *FunctionSpec) Reset()

func (*FunctionSpec) String

func (x *FunctionSpec) String() string

type GlobalWindowsPayload

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

By default, all data in a PCollection is assigned to the single global window. See BeamConstants for the time span this window encompasses.

See https://beam.apache.org/documentation/programming-guide/#single-global-window for additional details.

func (*GlobalWindowsPayload) Descriptor deprecated

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

Deprecated: Use GlobalWindowsPayload.ProtoReflect.Descriptor instead.

func (*GlobalWindowsPayload) ProtoMessage

func (*GlobalWindowsPayload) ProtoMessage()

func (*GlobalWindowsPayload) ProtoReflect

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

func (*GlobalWindowsPayload) Reset

func (x *GlobalWindowsPayload) Reset()

func (*GlobalWindowsPayload) String

func (x *GlobalWindowsPayload) String() string

type GlobalWindowsPayload_Enum

type GlobalWindowsPayload_Enum int32
const (
	GlobalWindowsPayload_PROPERTIES GlobalWindowsPayload_Enum = 0
)

func (GlobalWindowsPayload_Enum) Descriptor

func (GlobalWindowsPayload_Enum) Enum

func (GlobalWindowsPayload_Enum) EnumDescriptor deprecated

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

Deprecated: Use GlobalWindowsPayload_Enum.Descriptor instead.

func (GlobalWindowsPayload_Enum) Number

func (GlobalWindowsPayload_Enum) String

func (x GlobalWindowsPayload_Enum) String() string

func (GlobalWindowsPayload_Enum) Type

type GroupIntoBatchesPayload

type GroupIntoBatchesPayload struct {

	// (Required) Max size of a batch.
	BatchSize int64 `protobuf:"varint,1,opt,name=batch_size,json=batchSize,proto3" json:"batch_size,omitempty"`
	// (Optional) Max duration a batch is allowed to be cached in states.
	MaxBufferingDurationMillis int64 `` /* 144-byte string literal not displayed */
	// contains filtered or unexported fields
}

Payload for GroupIntoBatches composite transform.

func (*GroupIntoBatchesPayload) Descriptor deprecated

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

Deprecated: Use GroupIntoBatchesPayload.ProtoReflect.Descriptor instead.

func (*GroupIntoBatchesPayload) GetBatchSize

func (x *GroupIntoBatchesPayload) GetBatchSize() int64

func (*GroupIntoBatchesPayload) GetMaxBufferingDurationMillis

func (x *GroupIntoBatchesPayload) GetMaxBufferingDurationMillis() int64

func (*GroupIntoBatchesPayload) ProtoMessage

func (*GroupIntoBatchesPayload) ProtoMessage()

func (*GroupIntoBatchesPayload) ProtoReflect

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

func (*GroupIntoBatchesPayload) Reset

func (x *GroupIntoBatchesPayload) Reset()

func (*GroupIntoBatchesPayload) String

func (x *GroupIntoBatchesPayload) String() string

type IsBounded

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

func (*IsBounded) Descriptor deprecated

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

Deprecated: Use IsBounded.ProtoReflect.Descriptor instead.

func (*IsBounded) ProtoMessage

func (*IsBounded) ProtoMessage()

func (*IsBounded) ProtoReflect

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

func (*IsBounded) Reset

func (x *IsBounded) Reset()

func (*IsBounded) String

func (x *IsBounded) String() string

type IsBounded_Enum

type IsBounded_Enum int32
const (
	IsBounded_UNSPECIFIED IsBounded_Enum = 0
	IsBounded_UNBOUNDED   IsBounded_Enum = 1
	IsBounded_BOUNDED     IsBounded_Enum = 2
)

func (IsBounded_Enum) Descriptor

func (IsBounded_Enum) Enum

func (x IsBounded_Enum) Enum() *IsBounded_Enum

func (IsBounded_Enum) EnumDescriptor deprecated

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

Deprecated: Use IsBounded_Enum.Descriptor instead.

func (IsBounded_Enum) Number

func (IsBounded_Enum) String

func (x IsBounded_Enum) String() string

func (IsBounded_Enum) Type

type IterableType

type IterableType struct {
	ElementType *FieldType `protobuf:"bytes,1,opt,name=element_type,json=elementType,proto3" json:"element_type,omitempty"`
	// contains filtered or unexported fields
}

func (*IterableType) Descriptor deprecated

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

Deprecated: Use IterableType.ProtoReflect.Descriptor instead.

func (*IterableType) GetElementType

func (x *IterableType) GetElementType() *FieldType

func (*IterableType) ProtoMessage

func (*IterableType) ProtoMessage()

func (*IterableType) ProtoReflect

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

func (*IterableType) Reset

func (x *IterableType) Reset()

func (*IterableType) String

func (x *IterableType) String() string

type IterableTypeValue

type IterableTypeValue struct {
	Element []*FieldValue `protobuf:"bytes,1,rep,name=element,proto3" json:"element,omitempty"`
	// contains filtered or unexported fields
}

func (*IterableTypeValue) Descriptor deprecated

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

Deprecated: Use IterableTypeValue.ProtoReflect.Descriptor instead.

func (*IterableTypeValue) GetElement

func (x *IterableTypeValue) GetElement() []*FieldValue

func (*IterableTypeValue) ProtoMessage

func (*IterableTypeValue) ProtoMessage()

func (*IterableTypeValue) ProtoReflect

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

func (*IterableTypeValue) Reset

func (x *IterableTypeValue) Reset()

func (*IterableTypeValue) String

func (x *IterableTypeValue) String() string

type LabelledPayload

type LabelledPayload struct {

	// (Required) A human readable label for the value.
	Label string `protobuf:"bytes,1,opt,name=label,proto3" json:"label,omitempty"`
	// (Required) A value which will be displayed to the user.
	//
	// Types that are assignable to Value:
	//	*LabelledPayload_StringValue
	//	*LabelledPayload_BoolValue
	//	*LabelledPayload_DoubleValue
	Value isLabelledPayload_Value `protobuf_oneof:"value"`
	// contains filtered or unexported fields
}

func (*LabelledPayload) Descriptor deprecated

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

Deprecated: Use LabelledPayload.ProtoReflect.Descriptor instead.

func (*LabelledPayload) GetBoolValue

func (x *LabelledPayload) GetBoolValue() bool

func (*LabelledPayload) GetDoubleValue

func (x *LabelledPayload) GetDoubleValue() float64

func (*LabelledPayload) GetLabel

func (x *LabelledPayload) GetLabel() string

func (*LabelledPayload) GetStringValue

func (x *LabelledPayload) GetStringValue() string

func (*LabelledPayload) GetValue

func (m *LabelledPayload) GetValue() isLabelledPayload_Value

func (*LabelledPayload) ProtoMessage

func (*LabelledPayload) ProtoMessage()

func (*LabelledPayload) ProtoReflect

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

func (*LabelledPayload) Reset

func (x *LabelledPayload) Reset()

func (*LabelledPayload) String

func (x *LabelledPayload) String() string

type LabelledPayload_BoolValue

type LabelledPayload_BoolValue struct {
	BoolValue bool `protobuf:"varint,3,opt,name=bool_value,json=boolValue,proto3,oneof"`
}

type LabelledPayload_DoubleValue

type LabelledPayload_DoubleValue struct {
	DoubleValue float64 `protobuf:"fixed64,4,opt,name=double_value,json=doubleValue,proto3,oneof"`
}

type LabelledPayload_StringValue

type LabelledPayload_StringValue struct {
	StringValue string `protobuf:"bytes,2,opt,name=string_value,json=stringValue,proto3,oneof"`
}

type LogicalType

type LogicalType struct {
	Urn            string      `protobuf:"bytes,1,opt,name=urn,proto3" json:"urn,omitempty"`
	Payload        []byte      `protobuf:"bytes,2,opt,name=payload,proto3" json:"payload,omitempty"`
	Representation *FieldType  `protobuf:"bytes,3,opt,name=representation,proto3" json:"representation,omitempty"`
	ArgumentType   *FieldType  `protobuf:"bytes,4,opt,name=argument_type,json=argumentType,proto3" json:"argument_type,omitempty"`
	Argument       *FieldValue `protobuf:"bytes,5,opt,name=argument,proto3" json:"argument,omitempty"`
	// contains filtered or unexported fields
}

func (*LogicalType) Descriptor deprecated

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

Deprecated: Use LogicalType.ProtoReflect.Descriptor instead.

func (*LogicalType) GetArgument

func (x *LogicalType) GetArgument() *FieldValue

func (*LogicalType) GetArgumentType

func (x *LogicalType) GetArgumentType() *FieldType

func (*LogicalType) GetPayload

func (x *LogicalType) GetPayload() []byte

func (*LogicalType) GetRepresentation

func (x *LogicalType) GetRepresentation() *FieldType

func (*LogicalType) GetUrn

func (x *LogicalType) GetUrn() string

func (*LogicalType) ProtoMessage

func (*LogicalType) ProtoMessage()

func (*LogicalType) ProtoReflect

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

func (*LogicalType) Reset

func (x *LogicalType) Reset()

func (*LogicalType) String

func (x *LogicalType) String() string

type LogicalTypeValue

type LogicalTypeValue struct {
	Value *FieldValue `protobuf:"bytes,1,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*LogicalTypeValue) Descriptor deprecated

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

Deprecated: Use LogicalTypeValue.ProtoReflect.Descriptor instead.

func (*LogicalTypeValue) GetValue

func (x *LogicalTypeValue) GetValue() *FieldValue

func (*LogicalTypeValue) ProtoMessage

func (*LogicalTypeValue) ProtoMessage()

func (*LogicalTypeValue) ProtoReflect

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

func (*LogicalTypeValue) Reset

func (x *LogicalTypeValue) Reset()

func (*LogicalTypeValue) String

func (x *LogicalTypeValue) String() string

type MapStateSpec

type MapStateSpec struct {
	KeyCoderId   string `protobuf:"bytes,1,opt,name=key_coder_id,json=keyCoderId,proto3" json:"key_coder_id,omitempty"`
	ValueCoderId string `protobuf:"bytes,2,opt,name=value_coder_id,json=valueCoderId,proto3" json:"value_coder_id,omitempty"`
	// contains filtered or unexported fields
}

func (*MapStateSpec) Descriptor deprecated

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

Deprecated: Use MapStateSpec.ProtoReflect.Descriptor instead.

func (*MapStateSpec) GetKeyCoderId

func (x *MapStateSpec) GetKeyCoderId() string

func (*MapStateSpec) GetValueCoderId

func (x *MapStateSpec) GetValueCoderId() string

func (*MapStateSpec) ProtoMessage

func (*MapStateSpec) ProtoMessage()

func (*MapStateSpec) ProtoReflect

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

func (*MapStateSpec) Reset

func (x *MapStateSpec) Reset()

func (*MapStateSpec) String

func (x *MapStateSpec) String() string

type MapType

type MapType struct {
	KeyType   *FieldType `protobuf:"bytes,1,opt,name=key_type,json=keyType,proto3" json:"key_type,omitempty"`
	ValueType *FieldType `protobuf:"bytes,2,opt,name=value_type,json=valueType,proto3" json:"value_type,omitempty"`
	// contains filtered or unexported fields
}

func (*MapType) Descriptor deprecated

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

Deprecated: Use MapType.ProtoReflect.Descriptor instead.

func (*MapType) GetKeyType

func (x *MapType) GetKeyType() *FieldType

func (*MapType) GetValueType

func (x *MapType) GetValueType() *FieldType

func (*MapType) ProtoMessage

func (*MapType) ProtoMessage()

func (*MapType) ProtoReflect

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

func (*MapType) Reset

func (x *MapType) Reset()

func (*MapType) String

func (x *MapType) String() string

type MapTypeEntry

type MapTypeEntry struct {
	Key   *FieldValue `protobuf:"bytes,1,opt,name=key,proto3" json:"key,omitempty"`
	Value *FieldValue `protobuf:"bytes,2,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*MapTypeEntry) Descriptor deprecated

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

Deprecated: Use MapTypeEntry.ProtoReflect.Descriptor instead.

func (*MapTypeEntry) GetKey

func (x *MapTypeEntry) GetKey() *FieldValue

func (*MapTypeEntry) GetValue

func (x *MapTypeEntry) GetValue() *FieldValue

func (*MapTypeEntry) ProtoMessage

func (*MapTypeEntry) ProtoMessage()

func (*MapTypeEntry) ProtoReflect

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

func (*MapTypeEntry) Reset

func (x *MapTypeEntry) Reset()

func (*MapTypeEntry) String

func (x *MapTypeEntry) String() string

type MapTypeValue

type MapTypeValue struct {
	Entries []*MapTypeEntry `protobuf:"bytes,1,rep,name=entries,proto3" json:"entries,omitempty"`
	// contains filtered or unexported fields
}

func (*MapTypeValue) Descriptor deprecated

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

Deprecated: Use MapTypeValue.ProtoReflect.Descriptor instead.

func (*MapTypeValue) GetEntries

func (x *MapTypeValue) GetEntries() []*MapTypeEntry

func (*MapTypeValue) ProtoMessage

func (*MapTypeValue) ProtoMessage()

func (*MapTypeValue) ProtoReflect

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

func (*MapTypeValue) Reset

func (x *MapTypeValue) Reset()

func (*MapTypeValue) String

func (x *MapTypeValue) String() string

type MavenPayload

type MavenPayload struct {

	// A string specifying Maven artifact.
	// The standard format is "groupId:artifactId:version[:packaging[:classifier]]"
	Artifact string `protobuf:"bytes,1,opt,name=artifact,proto3" json:"artifact,omitempty"`
	// (Optional) Repository URL. If not specified, Maven central is used by default.
	RepositoryUrl string `protobuf:"bytes,2,opt,name=repository_url,json=repositoryUrl,proto3" json:"repository_url,omitempty"`
	// contains filtered or unexported fields
}

func (*MavenPayload) Descriptor deprecated

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

Deprecated: Use MavenPayload.ProtoReflect.Descriptor instead.

func (*MavenPayload) GetArtifact

func (x *MavenPayload) GetArtifact() string

func (*MavenPayload) GetRepositoryUrl

func (x *MavenPayload) GetRepositoryUrl() string

func (*MavenPayload) ProtoMessage

func (*MavenPayload) ProtoMessage()

func (*MavenPayload) ProtoReflect

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

func (*MavenPayload) Reset

func (x *MavenPayload) Reset()

func (*MavenPayload) String

func (x *MavenPayload) String() string

type MergeStatus

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

Whether or not a PCollection's WindowFn is non-merging, merging, or merging-but-already-merged, in which case a subsequent GroupByKey is almost always going to do something the user does not want

func (*MergeStatus) Descriptor deprecated

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

Deprecated: Use MergeStatus.ProtoReflect.Descriptor instead.

func (*MergeStatus) ProtoMessage

func (*MergeStatus) ProtoMessage()

func (*MergeStatus) ProtoReflect

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

func (*MergeStatus) Reset

func (x *MergeStatus) Reset()

func (*MergeStatus) String

func (x *MergeStatus) String() string

type MergeStatus_Enum

type MergeStatus_Enum int32
const (
	MergeStatus_UNSPECIFIED MergeStatus_Enum = 0
	// The WindowFn does not require merging.
	// Examples: global window, FixedWindows, SlidingWindows
	MergeStatus_NON_MERGING MergeStatus_Enum = 1
	// The WindowFn is merging and the PCollection has not had merging
	// performed.
	// Example: Sessions prior to a GroupByKey
	MergeStatus_NEEDS_MERGE MergeStatus_Enum = 2
	// The WindowFn is merging and the PCollection has had merging occur
	// already.
	// Example: Sessions after a GroupByKey
	MergeStatus_ALREADY_MERGED MergeStatus_Enum = 3
)

func (MergeStatus_Enum) Descriptor

func (MergeStatus_Enum) Enum

func (MergeStatus_Enum) EnumDescriptor deprecated

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

Deprecated: Use MergeStatus_Enum.Descriptor instead.

func (MergeStatus_Enum) Number

func (MergeStatus_Enum) String

func (x MergeStatus_Enum) String() string

func (MergeStatus_Enum) Type

type MessageWithComponents

type MessageWithComponents struct {

	// (Optional) The by-reference components of the root message,
	// enabling a standalone message.
	//
	// If this is absent, it is expected that there are no
	// references.
	Components *Components `protobuf:"bytes,1,opt,name=components,proto3" json:"components,omitempty"`
	// (Required) The root message that may contain pointers
	// that should be resolved by looking inside components.
	//
	// Types that are assignable to Root:
	//	*MessageWithComponents_Coder
	//	*MessageWithComponents_CombinePayload
	//	*MessageWithComponents_FunctionSpec
	//	*MessageWithComponents_ParDoPayload
	//	*MessageWithComponents_Ptransform
	//	*MessageWithComponents_Pcollection
	//	*MessageWithComponents_ReadPayload
	//	*MessageWithComponents_SideInput
	//	*MessageWithComponents_WindowIntoPayload
	//	*MessageWithComponents_WindowingStrategy
	Root isMessageWithComponents_Root `protobuf_oneof:"root"`
	// contains filtered or unexported fields
}

A disjoint union of all the things that may contain references that require Components to resolve.

func (*MessageWithComponents) Descriptor deprecated

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

Deprecated: Use MessageWithComponents.ProtoReflect.Descriptor instead.

func (*MessageWithComponents) GetCoder

func (x *MessageWithComponents) GetCoder() *Coder

func (*MessageWithComponents) GetCombinePayload

func (x *MessageWithComponents) GetCombinePayload() *CombinePayload

func (*MessageWithComponents) GetComponents

func (x *MessageWithComponents) GetComponents() *Components

func (*MessageWithComponents) GetFunctionSpec

func (x *MessageWithComponents) GetFunctionSpec() *FunctionSpec

func (*MessageWithComponents) GetParDoPayload

func (x *MessageWithComponents) GetParDoPayload() *ParDoPayload

func (*MessageWithComponents) GetPcollection

func (x *MessageWithComponents) GetPcollection() *PCollection

func (*MessageWithComponents) GetPtransform

func (x *MessageWithComponents) GetPtransform() *PTransform

func (*MessageWithComponents) GetReadPayload

func (x *MessageWithComponents) GetReadPayload() *ReadPayload

func (*MessageWithComponents) GetRoot

func (m *MessageWithComponents) GetRoot() isMessageWithComponents_Root

func (*MessageWithComponents) GetSideInput

func (x *MessageWithComponents) GetSideInput() *SideInput

func (*MessageWithComponents) GetWindowIntoPayload

func (x *MessageWithComponents) GetWindowIntoPayload() *WindowIntoPayload

func (*MessageWithComponents) GetWindowingStrategy

func (x *MessageWithComponents) GetWindowingStrategy() *WindowingStrategy

func (*MessageWithComponents) ProtoMessage

func (*MessageWithComponents) ProtoMessage()

func (*MessageWithComponents) ProtoReflect

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

func (*MessageWithComponents) Reset

func (x *MessageWithComponents) Reset()

func (*MessageWithComponents) String

func (x *MessageWithComponents) String() string

type MessageWithComponents_Coder

type MessageWithComponents_Coder struct {
	Coder *Coder `protobuf:"bytes,2,opt,name=coder,proto3,oneof"`
}

type MessageWithComponents_CombinePayload

type MessageWithComponents_CombinePayload struct {
	CombinePayload *CombinePayload `protobuf:"bytes,3,opt,name=combine_payload,json=combinePayload,proto3,oneof"`
}

type MessageWithComponents_FunctionSpec

type MessageWithComponents_FunctionSpec struct {
	FunctionSpec *FunctionSpec `protobuf:"bytes,4,opt,name=function_spec,json=functionSpec,proto3,oneof"`
}

type MessageWithComponents_ParDoPayload

type MessageWithComponents_ParDoPayload struct {
	ParDoPayload *ParDoPayload `protobuf:"bytes,6,opt,name=par_do_payload,json=parDoPayload,proto3,oneof"`
}

type MessageWithComponents_Pcollection

type MessageWithComponents_Pcollection struct {
	Pcollection *PCollection `protobuf:"bytes,8,opt,name=pcollection,proto3,oneof"`
}

type MessageWithComponents_Ptransform

type MessageWithComponents_Ptransform struct {
	Ptransform *PTransform `protobuf:"bytes,7,opt,name=ptransform,proto3,oneof"`
}

type MessageWithComponents_ReadPayload

type MessageWithComponents_ReadPayload struct {
	ReadPayload *ReadPayload `protobuf:"bytes,9,opt,name=read_payload,json=readPayload,proto3,oneof"`
}

type MessageWithComponents_SideInput

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

type MessageWithComponents_WindowIntoPayload

type MessageWithComponents_WindowIntoPayload struct {
	WindowIntoPayload *WindowIntoPayload `protobuf:"bytes,12,opt,name=window_into_payload,json=windowIntoPayload,proto3,oneof"`
}

type MessageWithComponents_WindowingStrategy

type MessageWithComponents_WindowingStrategy struct {
	WindowingStrategy *WindowingStrategy `protobuf:"bytes,13,opt,name=windowing_strategy,json=windowingStrategy,proto3,oneof"`
}

type MonitoringInfo

type MonitoringInfo struct {

	// (Required) Defines the semantic meaning of the metric or monitored state.
	//
	// See MonitoringInfoSpecs.Enum for the set of well known metrics/monitored
	// state.
	Urn string `protobuf:"bytes,1,opt,name=urn,proto3" json:"urn,omitempty"`
	// (Required) Defines the encoding and aggregation method for the payload.
	//
	// See MonitoringInfoTypeUrns.Enum for the set of well known types.
	Type string `protobuf:"bytes,2,opt,name=type,proto3" json:"type,omitempty"`
	// (Required) The metric or monitored state encoded as per the specification
	// defined by the type.
	Payload []byte `protobuf:"bytes,3,opt,name=payload,proto3" json:"payload,omitempty"`
	// A set of key and value labels which define the scope of the metric. For
	// well known URNs, the set of required labels is provided by the associated
	// MonitoringInfoSpec.
	//
	// Either a well defined entity id for matching the enum names in
	// the MonitoringInfoLabels enum or any arbitrary label
	// set by a custom metric or user metric.
	//
	// A monitoring system is expected to be able to aggregate the metrics
	// together for all updates having the same URN and labels. Some systems such
	// as Stackdriver will be able to aggregate the metrics using a subset of the
	// provided labels
	Labels map[string]string `` /* 153-byte string literal not displayed */
	// This indicates the start of the time range over which this value was
	// measured.
	// This is needed by some external metric aggregation services
	// to indicate when the reporter of the metric first began collecting the
	// cumulative value for the timeseries.
	// If the SDK Harness restarts, it should reset the start_time, and reset
	// the collection of cumulative metrics (i.e. start to count again from 0).
	// HarnessMonitoringInfos should set this start_time once, when the
	// MonitoringInfo is first reported.
	// ProcessBundle MonitoringInfos should set a start_time for each bundle.
	StartTime *timestamp.Timestamp `protobuf:"bytes,5,opt,name=start_time,json=startTime,proto3" json:"start_time,omitempty"`
	// contains filtered or unexported fields
}

func (*MonitoringInfo) Descriptor deprecated

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

Deprecated: Use MonitoringInfo.ProtoReflect.Descriptor instead.

func (*MonitoringInfo) GetLabels

func (x *MonitoringInfo) GetLabels() map[string]string

func (*MonitoringInfo) GetPayload

func (x *MonitoringInfo) GetPayload() []byte

func (*MonitoringInfo) GetStartTime

func (x *MonitoringInfo) GetStartTime() *timestamp.Timestamp

func (*MonitoringInfo) GetType

func (x *MonitoringInfo) GetType() string

func (*MonitoringInfo) GetUrn

func (x *MonitoringInfo) GetUrn() string

func (*MonitoringInfo) ProtoMessage

func (*MonitoringInfo) ProtoMessage()

func (*MonitoringInfo) ProtoReflect

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

func (*MonitoringInfo) Reset

func (x *MonitoringInfo) Reset()

func (*MonitoringInfo) String

func (x *MonitoringInfo) String() string

type MonitoringInfoLabelProps

type MonitoringInfoLabelProps struct {

	// The label key to use in the MonitoringInfo labels map.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// contains filtered or unexported fields
}

A set of properties for the MonitoringInfoLabel, this is useful to obtain the proper label string for the MonitoringInfoLabel.

func (*MonitoringInfoLabelProps) Descriptor deprecated

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

Deprecated: Use MonitoringInfoLabelProps.ProtoReflect.Descriptor instead.

func (*MonitoringInfoLabelProps) GetName

func (x *MonitoringInfoLabelProps) GetName() string

func (*MonitoringInfoLabelProps) ProtoMessage

func (*MonitoringInfoLabelProps) ProtoMessage()

func (*MonitoringInfoLabelProps) ProtoReflect

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

func (*MonitoringInfoLabelProps) Reset

func (x *MonitoringInfoLabelProps) Reset()

func (*MonitoringInfoLabelProps) String

func (x *MonitoringInfoLabelProps) String() string

type MonitoringInfoSpec

type MonitoringInfoSpec struct {

	// Defines the semantic meaning of the metric or monitored state.
	//
	// See MonitoringInfoSpecs.Enum for the set of well known metrics/monitored
	// state.
	Urn string `protobuf:"bytes,1,opt,name=urn,proto3" json:"urn,omitempty"`
	// Defines the required encoding and aggregation method for the payload.
	//
	// See MonitoringInfoTypeUrns.Enum for the set of well known types.
	Type string `protobuf:"bytes,2,opt,name=type,proto3" json:"type,omitempty"`
	// The list of required labels for the specified urn and type.
	RequiredLabels []string `protobuf:"bytes,3,rep,name=required_labels,json=requiredLabels,proto3" json:"required_labels,omitempty"`
	// Extra non functional parts of the spec for descriptive purposes.
	// i.e. description, units, etc.
	Annotations []*Annotation `protobuf:"bytes,4,rep,name=annotations,proto3" json:"annotations,omitempty"`
	// contains filtered or unexported fields
}

A specification for describing a well known MonitoringInfo.

All specifications are uniquely identified by the urn.

func (*MonitoringInfoSpec) Descriptor deprecated

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

Deprecated: Use MonitoringInfoSpec.ProtoReflect.Descriptor instead.

func (*MonitoringInfoSpec) GetAnnotations

func (x *MonitoringInfoSpec) GetAnnotations() []*Annotation

func (*MonitoringInfoSpec) GetRequiredLabels

func (x *MonitoringInfoSpec) GetRequiredLabels() []string

func (*MonitoringInfoSpec) GetType

func (x *MonitoringInfoSpec) GetType() string

func (*MonitoringInfoSpec) GetUrn

func (x *MonitoringInfoSpec) GetUrn() string

func (*MonitoringInfoSpec) ProtoMessage

func (*MonitoringInfoSpec) ProtoMessage()

func (*MonitoringInfoSpec) ProtoReflect

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

func (*MonitoringInfoSpec) Reset

func (x *MonitoringInfoSpec) Reset()

func (*MonitoringInfoSpec) String

func (x *MonitoringInfoSpec) String() string

type MonitoringInfoSpecs

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

A set of well known MonitoringInfo specifications.

func (*MonitoringInfoSpecs) Descriptor deprecated

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

Deprecated: Use MonitoringInfoSpecs.ProtoReflect.Descriptor instead.

func (*MonitoringInfoSpecs) ProtoMessage

func (*MonitoringInfoSpecs) ProtoMessage()

func (*MonitoringInfoSpecs) ProtoReflect

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

func (*MonitoringInfoSpecs) Reset

func (x *MonitoringInfoSpecs) Reset()

func (*MonitoringInfoSpecs) String

func (x *MonitoringInfoSpecs) String() string

type MonitoringInfoSpecs_Enum

type MonitoringInfoSpecs_Enum int32
const (
	// Represents an integer counter where values are summed across bundles.
	MonitoringInfoSpecs_USER_SUM_INT64 MonitoringInfoSpecs_Enum = 0
	// Represents a double counter where values are summed across bundles.
	MonitoringInfoSpecs_USER_SUM_DOUBLE MonitoringInfoSpecs_Enum = 1
	// Represents a distribution of an integer value where:
	//   - count: represents the number of values seen across all bundles
	//   - sum: represents the total of the value across all bundles
	//   - min: represents the smallest value seen across all bundles
	//   - max: represents the largest value seen across all bundles
	MonitoringInfoSpecs_USER_DISTRIBUTION_INT64 MonitoringInfoSpecs_Enum = 2
	// Represents a distribution of a double value where:
	//   - count: represents the number of values seen across all bundles
	//   - sum: represents the total of the value across all bundles
	//   - min: represents the smallest value seen across all bundles
	//   - max: represents the largest value seen across all bundles
	MonitoringInfoSpecs_USER_DISTRIBUTION_DOUBLE MonitoringInfoSpecs_Enum = 3
	// Represents the latest seen integer value. The timestamp is used to
	// provide an "ordering" over multiple values to determine which is the
	// latest.
	MonitoringInfoSpecs_USER_LATEST_INT64 MonitoringInfoSpecs_Enum = 4
	// Represents the latest seen double value. The timestamp is used to
	// provide an "ordering" over multiple values to determine which is the
	// latest.
	MonitoringInfoSpecs_USER_LATEST_DOUBLE MonitoringInfoSpecs_Enum = 5
	// Represents the largest set of integer values seen across bundles.
	MonitoringInfoSpecs_USER_TOP_N_INT64 MonitoringInfoSpecs_Enum = 6
	// Represents the largest set of double values seen across bundles.
	MonitoringInfoSpecs_USER_TOP_N_DOUBLE MonitoringInfoSpecs_Enum = 7
	// Represents the smallest set of integer values seen across bundles.
	MonitoringInfoSpecs_USER_BOTTOM_N_INT64 MonitoringInfoSpecs_Enum = 8
	// Represents the smallest set of double values seen across bundles.
	MonitoringInfoSpecs_USER_BOTTOM_N_DOUBLE MonitoringInfoSpecs_Enum = 9
	MonitoringInfoSpecs_ELEMENT_COUNT        MonitoringInfoSpecs_Enum = 10
	MonitoringInfoSpecs_SAMPLED_BYTE_SIZE    MonitoringInfoSpecs_Enum = 11
	MonitoringInfoSpecs_START_BUNDLE_MSECS   MonitoringInfoSpecs_Enum = 12
	MonitoringInfoSpecs_PROCESS_BUNDLE_MSECS MonitoringInfoSpecs_Enum = 13
	MonitoringInfoSpecs_FINISH_BUNDLE_MSECS  MonitoringInfoSpecs_Enum = 14
	MonitoringInfoSpecs_TOTAL_MSECS          MonitoringInfoSpecs_Enum = 15
	// All values reported across all beam:metric:ptransform_progress:.*:v1
	// metrics are of the same magnitude.
	MonitoringInfoSpecs_WORK_REMAINING MonitoringInfoSpecs_Enum = 16
	// All values reported across all beam:metric:ptransform_progress:.*:v1
	// metrics are of the same magnitude.
	MonitoringInfoSpecs_WORK_COMPLETED MonitoringInfoSpecs_Enum = 17
	// The (0-based) index of the latest item processed from the data channel.
	// This gives an indication of the SDKs progress through the data channel,
	// and is a lower bound on where it is able to split.
	// For an SDK that processes items sequentially, this is equivalently the
	// number of items fully processed (or -1 if processing has not yet started).
	MonitoringInfoSpecs_DATA_CHANNEL_READ_INDEX MonitoringInfoSpecs_Enum = 18
	MonitoringInfoSpecs_API_REQUEST_COUNT       MonitoringInfoSpecs_Enum = 19
	MonitoringInfoSpecs_API_REQUEST_LATENCIES   MonitoringInfoSpecs_Enum = 20
)

func (MonitoringInfoSpecs_Enum) Descriptor

func (MonitoringInfoSpecs_Enum) Enum

func (MonitoringInfoSpecs_Enum) EnumDescriptor deprecated

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

Deprecated: Use MonitoringInfoSpecs_Enum.Descriptor instead.

func (MonitoringInfoSpecs_Enum) Number

func (MonitoringInfoSpecs_Enum) String

func (x MonitoringInfoSpecs_Enum) String() string

func (MonitoringInfoSpecs_Enum) Type

type MonitoringInfoTypeUrns

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

A set of well known URNs that specify the encoding and aggregation method.

func (*MonitoringInfoTypeUrns) Descriptor deprecated

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

Deprecated: Use MonitoringInfoTypeUrns.ProtoReflect.Descriptor instead.

func (*MonitoringInfoTypeUrns) ProtoMessage

func (*MonitoringInfoTypeUrns) ProtoMessage()

func (*MonitoringInfoTypeUrns) ProtoReflect

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

func (*MonitoringInfoTypeUrns) Reset

func (x *MonitoringInfoTypeUrns) Reset()

func (*MonitoringInfoTypeUrns) String

func (x *MonitoringInfoTypeUrns) String() string

type MonitoringInfoTypeUrns_Enum

type MonitoringInfoTypeUrns_Enum int32
const (
	// Represents an integer counter where values are summed across bundles.
	//
	// Encoding: <value>
	//   - value: beam:coder:varint:v1
	MonitoringInfoTypeUrns_SUM_INT64_TYPE MonitoringInfoTypeUrns_Enum = 0
	// Represents a double counter where values are summed across bundles.
	//
	// Encoding: <value>
	//   value: beam:coder:double:v1
	MonitoringInfoTypeUrns_SUM_DOUBLE_TYPE MonitoringInfoTypeUrns_Enum = 1
	// Represents a distribution of an integer value where:
	//   - count: represents the number of values seen across all bundles
	//   - sum: represents the total of the value across all bundles
	//   - min: represents the smallest value seen across all bundles
	//   - max: represents the largest value seen across all bundles
	//
	// Encoding: <count><sum><min><max>
	//   - count: beam:coder:varint:v1
	//   - sum:   beam:coder:varint:v1
	//   - min:   beam:coder:varint:v1
	//   - max:   beam:coder:varint:v1
	MonitoringInfoTypeUrns_DISTRIBUTION_INT64_TYPE MonitoringInfoTypeUrns_Enum = 2
	// Represents a distribution of a double value where:
	//   - count: represents the number of values seen across all bundles
	//   - sum: represents the total of the value across all bundles
	//   - min: represents the smallest value seen across all bundles
	//   - max: represents the largest value seen across all bundles
	//
	// Encoding: <count><sum><min><max>
	//   - count: beam:coder:varint:v1
	//   - sum:   beam:coder:double:v1
	//   - min:   beam:coder:double:v1
	//   - max:   beam:coder:double:v1
	MonitoringInfoTypeUrns_DISTRIBUTION_DOUBLE_TYPE MonitoringInfoTypeUrns_Enum = 3
	// Represents the latest seen integer value. The timestamp is used to
	// provide an "ordering" over multiple values to determine which is the
	// latest.
	//
	// Encoding: <timestamp><value>
	//   - timestamp: beam:coder:varint:v1     (milliseconds since epoch)
	//   - value:     beam:coder:varint:v1
	MonitoringInfoTypeUrns_LATEST_INT64_TYPE MonitoringInfoTypeUrns_Enum = 4
	// Represents the latest seen double value. The timestamp is used to
	// provide an "ordering" over multiple values to determine which is the
	// latest.
	//
	// Encoding: <timestamp><value>
	//   - timestamp: beam:coder:varint:v1     (milliseconds since epoch)
	//   - value:     beam:coder:double:v1
	MonitoringInfoTypeUrns_LATEST_DOUBLE_TYPE MonitoringInfoTypeUrns_Enum = 5
	// Represents the largest set of integer values seen across bundles.
	//
	// Encoding: <iter><value1><value2>...<valueN></iter>
	//   - iter:   beam:coder:iterable:v1
	//   - valueX: beam:coder:varint:v1
	MonitoringInfoTypeUrns_TOP_N_INT64_TYPE MonitoringInfoTypeUrns_Enum = 6
	// Represents the largest set of double values seen across bundles.
	//
	// Encoding: <iter><value1><value2>...<valueN></iter>
	//   - iter:   beam:coder:iterable:v1
	//   - valueX: beam:coder<beam:coder:double:v1
	MonitoringInfoTypeUrns_TOP_N_DOUBLE_TYPE MonitoringInfoTypeUrns_Enum = 7
	// Represents the smallest set of integer values seen across bundles.
	//
	// Encoding: <iter><value1><value2>...<valueN></iter>
	//   - iter:   beam:coder:iterable:v1
	//   - valueX: beam:coder:varint:v1
	MonitoringInfoTypeUrns_BOTTOM_N_INT64_TYPE MonitoringInfoTypeUrns_Enum = 8
	// Represents the smallest set of double values seen across bundles.
	//
	// Encoding: <iter><value1><value2>...<valueN></iter>
	//   - iter:   beam:coder:iterable:v1
	//   - valueX: beam:coder:double:v1
	MonitoringInfoTypeUrns_BOTTOM_N_DOUBLE_TYPE MonitoringInfoTypeUrns_Enum = 9
	// Encoding: <iter><value1><value2>...<valueN></iter>
	//   - iter:   beam:coder:iterable:v1
	//   - valueX: beam:coder:double:v1
	MonitoringInfoTypeUrns_PROGRESS_TYPE MonitoringInfoTypeUrns_Enum = 10
)

func (MonitoringInfoTypeUrns_Enum) Descriptor

func (MonitoringInfoTypeUrns_Enum) Enum

func (MonitoringInfoTypeUrns_Enum) EnumDescriptor deprecated

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

Deprecated: Use MonitoringInfoTypeUrns_Enum.Descriptor instead.

func (MonitoringInfoTypeUrns_Enum) Number

func (MonitoringInfoTypeUrns_Enum) String

func (MonitoringInfoTypeUrns_Enum) Type

type MonitoringInfo_MonitoringInfoLabels

type MonitoringInfo_MonitoringInfoLabels int32
const (
	// The values used for TRANSFORM, PCOLLECTION, WINDOWING_STRATEGY
	// CODER, ENVIRONMENT, etc. must always match the keys used to
	// refer to them. For actively processed bundles, these should match the
	// values within the ProcessBundleDescriptor. For job management APIs,
	// these should match values within the original pipeline representation.
	MonitoringInfo_TRANSFORM           MonitoringInfo_MonitoringInfoLabels = 0
	MonitoringInfo_PCOLLECTION         MonitoringInfo_MonitoringInfoLabels = 1
	MonitoringInfo_WINDOWING_STRATEGY  MonitoringInfo_MonitoringInfoLabels = 2
	MonitoringInfo_CODER               MonitoringInfo_MonitoringInfoLabels = 3
	MonitoringInfo_ENVIRONMENT         MonitoringInfo_MonitoringInfoLabels = 4
	MonitoringInfo_NAMESPACE           MonitoringInfo_MonitoringInfoLabels = 5
	MonitoringInfo_NAME                MonitoringInfo_MonitoringInfoLabels = 6
	MonitoringInfo_SERVICE             MonitoringInfo_MonitoringInfoLabels = 7
	MonitoringInfo_METHOD              MonitoringInfo_MonitoringInfoLabels = 8
	MonitoringInfo_RESOURCE            MonitoringInfo_MonitoringInfoLabels = 9
	MonitoringInfo_STATUS              MonitoringInfo_MonitoringInfoLabels = 10
	MonitoringInfo_BIGQUERY_PROJECT_ID MonitoringInfo_MonitoringInfoLabels = 11
	MonitoringInfo_BIGQUERY_DATASET    MonitoringInfo_MonitoringInfoLabels = 12
	MonitoringInfo_BIGQUERY_TABLE      MonitoringInfo_MonitoringInfoLabels = 13
	MonitoringInfo_BIGQUERY_VIEW       MonitoringInfo_MonitoringInfoLabels = 14
	MonitoringInfo_BIGQUERY_QUERY_NAME MonitoringInfo_MonitoringInfoLabels = 15
)

func (MonitoringInfo_MonitoringInfoLabels) Descriptor

func (MonitoringInfo_MonitoringInfoLabels) Enum

func (MonitoringInfo_MonitoringInfoLabels) EnumDescriptor deprecated

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

Deprecated: Use MonitoringInfo_MonitoringInfoLabels.Descriptor instead.

func (MonitoringInfo_MonitoringInfoLabels) Number

func (MonitoringInfo_MonitoringInfoLabels) String

func (MonitoringInfo_MonitoringInfoLabels) Type

type OnTimeBehavior

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

Controls whether or not an aggregating transform should output data when an on-time pane is empty.

func (*OnTimeBehavior) Descriptor deprecated

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

Deprecated: Use OnTimeBehavior.ProtoReflect.Descriptor instead.

func (*OnTimeBehavior) ProtoMessage

func (*OnTimeBehavior) ProtoMessage()

func (*OnTimeBehavior) ProtoReflect

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

func (*OnTimeBehavior) Reset

func (x *OnTimeBehavior) Reset()

func (*OnTimeBehavior) String

func (x *OnTimeBehavior) String() string

type OnTimeBehavior_Enum

type OnTimeBehavior_Enum int32
const (
	OnTimeBehavior_UNSPECIFIED OnTimeBehavior_Enum = 0
	// Always fire the on-time pane. Even if there is no new data since
	// the previous firing, an element will be produced.
	OnTimeBehavior_FIRE_ALWAYS OnTimeBehavior_Enum = 1
	// Only fire the on-time pane if there is new data since the previous firing.
	OnTimeBehavior_FIRE_IF_NONEMPTY OnTimeBehavior_Enum = 2
)

func (OnTimeBehavior_Enum) Descriptor

func (OnTimeBehavior_Enum) Enum

func (OnTimeBehavior_Enum) EnumDescriptor deprecated

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

Deprecated: Use OnTimeBehavior_Enum.Descriptor instead.

func (OnTimeBehavior_Enum) Number

func (OnTimeBehavior_Enum) String

func (x OnTimeBehavior_Enum) String() string

func (OnTimeBehavior_Enum) Type

type Option

type Option struct {

	// REQUIRED. Identifier for the option.
	Name string `protobuf:"bytes,1,opt,name=name,proto3" json:"name,omitempty"`
	// OPTIONAL. Type specifer for the structure of value.
	// If not present, assumes no additional configuration is needed
	// for this option and value is ignored.
	Type  *FieldType  `protobuf:"bytes,2,opt,name=type,proto3" json:"type,omitempty"`
	Value *FieldValue `protobuf:"bytes,3,opt,name=value,proto3" json:"value,omitempty"`
	// contains filtered or unexported fields
}

func (*Option) Descriptor deprecated

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

Deprecated: Use Option.ProtoReflect.Descriptor instead.

func (*Option) GetName

func (x *Option) GetName() string

func (*Option) GetType

func (x *Option) GetType() *FieldType

func (*Option) GetValue

func (x *Option) GetValue() *FieldValue

func (*Option) ProtoMessage

func (*Option) ProtoMessage()

func (*Option) ProtoReflect

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

func (*Option) Reset

func (x *Option) Reset()

func (*Option) String

func (x *Option) String() string

type OrderedListStateSpec

type OrderedListStateSpec struct {
	ElementCoderId string `protobuf:"bytes,1,opt,name=element_coder_id,json=elementCoderId,proto3" json:"element_coder_id,omitempty"`
	// contains filtered or unexported fields
}

func (*OrderedListStateSpec) Descriptor deprecated

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

Deprecated: Use OrderedListStateSpec.ProtoReflect.Descriptor instead.

func (*OrderedListStateSpec) GetElementCoderId

func (x *OrderedListStateSpec) GetElementCoderId() string

func (*OrderedListStateSpec) ProtoMessage

func (*OrderedListStateSpec) ProtoMessage()

func (*OrderedListStateSpec) ProtoReflect

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

func (*OrderedListStateSpec) Reset

func (x *OrderedListStateSpec) Reset()

func (*OrderedListStateSpec) String

func (x *OrderedListStateSpec) String() string

type OutputTime

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

When a number of windowed, timestamped inputs are aggregated, the timestamp for the resulting output.

func (*OutputTime) Descriptor deprecated

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

Deprecated: Use OutputTime.ProtoReflect.Descriptor instead.

func (*OutputTime) ProtoMessage

func (*OutputTime) ProtoMessage()

func (*OutputTime) ProtoReflect

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

func (*OutputTime) Reset

func (x *OutputTime) Reset()

func (*OutputTime) String

func (x *OutputTime) String() string

type OutputTime_Enum

type OutputTime_Enum int32
const (
	OutputTime_UNSPECIFIED OutputTime_Enum = 0
	// The output has the timestamp of the end of the window.
	OutputTime_END_OF_WINDOW OutputTime_Enum = 1
	// The output has the latest timestamp of the input elements since
	// the last output.
	OutputTime_LATEST_IN_PANE OutputTime_Enum = 2
	// The output has the earliest timestamp of the input elements since
	// the last output.
	OutputTime_EARLIEST_IN_PANE OutputTime_Enum = 3
)

func (OutputTime_Enum) Descriptor

func (OutputTime_Enum) Enum

func (x OutputTime_Enum) Enum() *OutputTime_Enum

func (OutputTime_Enum) EnumDescriptor deprecated

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

Deprecated: Use OutputTime_Enum.Descriptor instead.

func (OutputTime_Enum) Number

func (OutputTime_Enum) String

func (x OutputTime_Enum) String() string

func (OutputTime_Enum) Type

type PCollection

type PCollection struct {

	// (Required) A unique name for the PCollection.
	//
	// Ideally, this should be stable over multiple evolutions of a pipeline
	// for the purposes of logging and associating pipeline state with a node,
	// etc.
	//
	// If it is not stable, then the runner decides what will happen. But, most
	// importantly, it must always be here, even if it is autogenerated.
	UniqueName string `protobuf:"bytes,1,opt,name=unique_name,json=uniqueName,proto3" json:"unique_name,omitempty"`
	// (Required) The id of the Coder for this PCollection.
	CoderId string `protobuf:"bytes,2,opt,name=coder_id,json=coderId,proto3" json:"coder_id,omitempty"`
	// (Required) Whether this PCollection is bounded or unbounded
	IsBounded IsBounded_Enum `` /* 143-byte string literal not displayed */
	// (Required) The id of the windowing strategy for this PCollection.
	WindowingStrategyId string `protobuf:"bytes,4,opt,name=windowing_strategy_id,json=windowingStrategyId,proto3" json:"windowing_strategy_id,omitempty"`
	// (Optional) Static display data for the PCollection. If there is none,
	// it may be omitted.
	DisplayData []*DisplayData `protobuf:"bytes,5,rep,name=display_data,json=displayData,proto3" json:"display_data,omitempty"`
	// contains filtered or unexported fields
}

A PCollection!

func (*PCollection) Descriptor deprecated

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

Deprecated: Use PCollection.ProtoReflect.Descriptor instead.

func (*PCollection) GetCoderId

func (x *PCollection) GetCoderId() string

func (*PCollection) GetDisplayData

func (x *PCollection) GetDisplayData() []*DisplayData

func (*PCollection) GetIsBounded

func (x *PCollection) GetIsBounded() IsBounded_Enum

func (*PCollection) GetUniqueName

func (x *PCollection) GetUniqueName() string

func (*PCollection) GetWindowingStrategyId

func (x *PCollection) GetWindowingStrategyId() string

func (*PCollection) ProtoMessage

func (*PCollection) ProtoMessage()

func (*PCollection) ProtoReflect

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

func (*PCollection) Reset

func (x *PCollection) Reset()

func (*PCollection) String

func (x *PCollection) String() string

type PTransform

type PTransform struct {

	// (Required) A unique name for the application node.
	//
	// Ideally, this should be stable over multiple evolutions of a pipeline
	// for the purposes of logging and associating pipeline state with a node,
	// etc.
	//
	// If it is not stable, then the runner decides what will happen. But, most
	// importantly, it must always be here and be unique, even if it is
	// autogenerated.
	UniqueName string `protobuf:"bytes,5,opt,name=unique_name,json=uniqueName,proto3" json:"unique_name,omitempty"`
	// (Optional) A URN and payload that, together, fully defined the semantics
	// of this transform.
	//
	// If absent, this must be an "anonymous" composite transform.
	//
	// For primitive transform in the Runner API, this is required, and the
	// payloads are well-defined messages. When the URN indicates ParDo it
	// is a ParDoPayload, and so on. For some special composite transforms,
	// the payload is also officially defined. See StandardPTransforms for
	// details.
	Spec *FunctionSpec `protobuf:"bytes,1,opt,name=spec,proto3" json:"spec,omitempty"`
	// (Optional) A list of the ids of transforms that it contains.
	//
	// Primitive transforms (see StandardPTransforms.Primitives) are not allowed
	// to specify subtransforms.
	//
	// Note that a composite transform may have zero subtransforms as long as it
	// only outputs PCollections that are in its inputs.
	Subtransforms []string `protobuf:"bytes,2,rep,name=subtransforms,proto3" json:"subtransforms,omitempty"`
	// (Required) A map from local names of inputs (unique only with this map, and
	// likely embedded in the transform payload and serialized user code) to
	// PCollection ids.
	//
	// The payload for this transform may clarify the relationship of these
	// inputs. For example:
	//
	//  - for a Flatten transform they are merged
	//  - for a ParDo transform, some may be side inputs
	//
	// All inputs are recorded here so that the topological ordering of
	// the graph is consistent whether or not the payload is understood.
	Inputs map[string]string `` /* 153-byte string literal not displayed */
	// (Required) A map from local names of outputs (unique only within this map,
	// and likely embedded in the transform payload and serialized user code)
	// to PCollection ids.
	//
	// The URN or payload for this transform node may clarify the type and
	// relationship of these outputs. For example:
	//
	//  - for a ParDo transform, these are tags on PCollections, which will be
	//    embedded in the DoFn.
	Outputs map[string]string `` /* 155-byte string literal not displayed */
	// (Optional) Static display data for this PTransform application. If
	// there is none, it may be omitted.
	DisplayData []*DisplayData `protobuf:"bytes,6,rep,name=display_data,json=displayData,proto3" json:"display_data,omitempty"`
	// Environment where the current PTransform should be executed in.
	//
	// Transforms that are required to be implemented by a runner must omit this.
	// All other transforms are required to specify this.
	EnvironmentId string `protobuf:"bytes,7,opt,name=environment_id,json=environmentId,proto3" json:"environment_id,omitempty"`
	// (Optional) A map from URNs designating a type of annotation, to the
	// annotation in binary format. For example, an annotation could indicate
	// that this PTransform has specific privacy properties.
	//
	// A runner MAY ignore types of annotations it doesn't understand. Therefore
	// annotations MUST NOT be used for metadata that can affect correct
	// execution of the transform.
	Annotations map[string][]byte `` /* 163-byte string literal not displayed */
	// contains filtered or unexported fields
}

Transforms are the operations in your pipeline, and provide a generic processing framework. You provide processing logic in the form of a function object (colloquially referred to as “user code”), and your user code is applied to each element of an input PCollection (or more than one PCollection). Depending on the pipeline runner and back-end that you choose, many different workers across a cluster may execute instances of your user code in parallel. The user code running on each worker generates the output elements that are ultimately added to the final output PCollection that the transform produces.

The Beam SDKs contain a number of different transforms that you can apply to your pipeline’s PCollections. These include general-purpose core transforms, such as ParDo or Combine. There are also pre-written composite transforms included in the SDKs, which combine one or more of the core transforms in a useful processing pattern, such as counting or combining elements in a collection. You can also define your own more complex composite transforms to fit your pipeline’s exact use case.

func (*PTransform) Descriptor deprecated

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

Deprecated: Use PTransform.ProtoReflect.Descriptor instead.

func (*PTransform) GetAnnotations

func (x *PTransform) GetAnnotations() map[string][]byte

func (*PTransform) GetDisplayData

func (x *PTransform) GetDisplayData() []*DisplayData

func (*PTransform) GetEnvironmentId

func (x *PTransform) GetEnvironmentId() string

func (*PTransform) GetInputs

func (x *PTransform) GetInputs() map[string]string

func (*PTransform) GetOutputs

func (x *PTransform) GetOutputs() map[string]string

func (*PTransform) GetSpec

func (x *PTransform) GetSpec() *FunctionSpec

func (*PTransform) GetSubtransforms

func (x *PTransform) GetSubtransforms() []string

func (*PTransform) GetUniqueName

func (x *PTransform) GetUniqueName() string

func (*PTransform) ProtoMessage

func (*PTransform) ProtoMessage()

func (*PTransform) ProtoReflect

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

func (*PTransform) Reset

func (x *PTransform) Reset()

func (*PTransform) String

func (x *PTransform) String() string

type ParDoPayload

type ParDoPayload struct {

	// (Required) The FunctionSpec of the DoFn.
	DoFn *FunctionSpec `protobuf:"bytes,1,opt,name=do_fn,json=doFn,proto3" json:"do_fn,omitempty"`
	// (Optional) A mapping of local input names to side inputs, describing
	// the expected access pattern.
	SideInputs map[string]*SideInput `` /* 179-byte string literal not displayed */
	// (Optional) A mapping of local state names to state specifications.
	// If this is set, the stateful processing requirement should also
	// be placed in the pipeline requirements.
	StateSpecs map[string]*StateSpec `` /* 179-byte string literal not displayed */
	// (Optional) A mapping of local timer family names to timer family
	// specifications. If this is set, the stateful processing requirement should
	// also be placed in the pipeline requirements.
	TimerFamilySpecs map[string]*TimerFamilySpec `` /* 199-byte string literal not displayed */
	// (Optional) Only set when this ParDo contains a splittable DoFn.
	// If this is set, the corresponding standard requirement should also
	// be placed in the pipeline requirements.
	RestrictionCoderId string `protobuf:"bytes,7,opt,name=restriction_coder_id,json=restrictionCoderId,proto3" json:"restriction_coder_id,omitempty"`
	// (Optional) Only set when this ParDo can request bundle finalization.
	// If this is set, the corresponding standard requirement should also
	// be placed in the pipeline requirements.
	RequestsFinalization bool `protobuf:"varint,8,opt,name=requests_finalization,json=requestsFinalization,proto3" json:"requests_finalization,omitempty"`
	// Whether this stage requires time sorted input.
	// If this is set, the corresponding standard requirement should also
	// be placed in the pipeline requirements.
	RequiresTimeSortedInput bool `` /* 136-byte string literal not displayed */
	// Whether this stage requires stable input.
	// If this is set, the corresponding standard requirement should also
	// be placed in the pipeline requirements.
	RequiresStableInput bool `protobuf:"varint,11,opt,name=requires_stable_input,json=requiresStableInput,proto3" json:"requires_stable_input,omitempty"`
	// contains filtered or unexported fields
}

The payload for the primitive ParDo transform.

func (*ParDoPayload) Descriptor deprecated

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

Deprecated: Use ParDoPayload.ProtoReflect.Descriptor instead.

func (*ParDoPayload) GetDoFn

func (x *ParDoPayload) GetDoFn() *FunctionSpec

func (*ParDoPayload) GetRequestsFinalization

func (x *ParDoPayload) GetRequestsFinalization() bool

func (*ParDoPayload) GetRequiresStableInput

func (x *ParDoPayload) GetRequiresStableInput() bool

func (*ParDoPayload) GetRequiresTimeSortedInput

func (x *ParDoPayload) GetRequiresTimeSortedInput() bool

func (*ParDoPayload) GetRestrictionCoderId

func (x *ParDoPayload) GetRestrictionCoderId() string

func (*ParDoPayload) GetSideInputs

func (x *ParDoPayload) GetSideInputs() map[string]*SideInput

func (*ParDoPayload) GetStateSpecs

func (x *ParDoPayload) GetStateSpecs() map[string]*StateSpec

func (*ParDoPayload) GetTimerFamilySpecs

func (x *ParDoPayload) GetTimerFamilySpecs() map[string]*TimerFamilySpec

func (*ParDoPayload) ProtoMessage

func (*ParDoPayload) ProtoMessage()

func (*ParDoPayload) ProtoReflect

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

func (*ParDoPayload) Reset

func (x *ParDoPayload) Reset()

func (*ParDoPayload) String

func (x *ParDoPayload) String() string

type Pipeline

type Pipeline struct {

	// (Required) The coders, UDFs, graph nodes, etc, that make up
	// this pipeline.
	Components *Components `protobuf:"bytes,1,opt,name=components,proto3" json:"components,omitempty"`
	// (Required) The ids of all PTransforms that are not contained within another
	// PTransform. These must be in shallow topological order, so that traversing
	// them recursively in this order yields a recursively topological traversal.
	RootTransformIds []string `protobuf:"bytes,2,rep,name=root_transform_ids,json=rootTransformIds,proto3" json:"root_transform_ids,omitempty"`
	// (Optional) Static display data for the pipeline. If there is none,
	// it may be omitted.
	DisplayData []*DisplayData `protobuf:"bytes,3,rep,name=display_data,json=displayData,proto3" json:"display_data,omitempty"`
	// (Optional) A set of requirements that the runner MUST understand and be
	// able to faithfully provide in order to execute this pipeline. These
	// may indicate that a runner must inspect new fields on a component or
	// provide additional guarantees when processing specific transforms.
	// A runner should reject any pipelines with unknown requirements.
	Requirements []string `protobuf:"bytes,4,rep,name=requirements,proto3" json:"requirements,omitempty"`
	// contains filtered or unexported fields
}

A Pipeline is a hierarchical graph of PTransforms, linked by PCollections. A typical graph may look like:

Impulse -> PCollection -> ParDo -> PCollection -> GroupByKey -> ...
                                \> PCollection -> ParDo      -> ...
                                               \> ParDo      -> ...
Impulse -> PCollection -> ParDo -> PCollection -> ...

This is represented by a number of by-reference maps to transforms, PCollections, SDK environments, coders, etc., for supporting compact reuse and arbitrary graph structure.

func (*Pipeline) Descriptor deprecated

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

Deprecated: Use Pipeline.ProtoReflect.Descriptor instead.

func (*Pipeline) GetComponents

func (x *Pipeline) GetComponents() *Components

func (*Pipeline) GetDisplayData

func (x *Pipeline) GetDisplayData() []*DisplayData

func (*Pipeline) GetRequirements

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

func (*Pipeline) GetRootTransformIds

func (x *Pipeline) GetRootTransformIds() []string

func (*Pipeline) ProtoMessage

func (*Pipeline) ProtoMessage()

func (*Pipeline) ProtoReflect

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

func (*Pipeline) Reset

func (x *Pipeline) Reset()

func (*Pipeline) String

func (x *Pipeline) String() string

type ProcessPayload

type ProcessPayload struct {
	Os      string            `protobuf:"bytes,1,opt,name=os,proto3" json:"os,omitempty"`           // "linux", "darwin", ..
	Arch    string            `protobuf:"bytes,2,opt,name=arch,proto3" json:"arch,omitempty"`       // "amd64", ..
	Command string            `protobuf:"bytes,3,opt,name=command,proto3" json:"command,omitempty"` // process to execute
	Env     map[string]string ``                                                                    // Environment variables
	/* 147-byte string literal not displayed */
	// contains filtered or unexported fields
}

func (*ProcessPayload) Descriptor deprecated

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

Deprecated: Use ProcessPayload.ProtoReflect.Descriptor instead.

func (*ProcessPayload) GetArch

func (x *ProcessPayload) GetArch() string

func (*ProcessPayload) GetCommand

func (x *ProcessPayload) GetCommand() string

func (*ProcessPayload) GetEnv

func (x *ProcessPayload) GetEnv() map[string]string

func (*ProcessPayload) GetOs

func (x *ProcessPayload) GetOs() string

func (*ProcessPayload) ProtoMessage

func (*ProcessPayload) ProtoMessage()

func (*ProcessPayload) ProtoReflect

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

func (*ProcessPayload) Reset

func (x *ProcessPayload) Reset()

func (*ProcessPayload) String

func (x *ProcessPayload) String() string

type PubSubReadPayload

type PubSubReadPayload struct {

	// Topic to read from. Exactly one of topic or subscription should be set.
	// Topic format is: /topics/project_id/subscription_name
	Topic string `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"`
	// Subscription to read from. Exactly one of topic or subscription should be set.
	// Subscription format is: /subscriptions/project_id/subscription_name
	Subscription string `protobuf:"bytes,2,opt,name=subscription,proto3" json:"subscription,omitempty"`
	// Attribute that provides element timestamps.
	TimestampAttribute string `protobuf:"bytes,3,opt,name=timestamp_attribute,json=timestampAttribute,proto3" json:"timestamp_attribute,omitempty"`
	// Attribute to be used for uniquely identifying messages.
	IdAttribute string `protobuf:"bytes,4,opt,name=id_attribute,json=idAttribute,proto3" json:"id_attribute,omitempty"`
	// If true, reads Pub/Sub payload as well as attributes. If false, reads only the payload.
	WithAttributes bool `protobuf:"varint,5,opt,name=with_attributes,json=withAttributes,proto3" json:"with_attributes,omitempty"`
	// If set, the topic is expected to be provided during runtime.
	TopicRuntimeOverridden string `` /* 129-byte string literal not displayed */
	// If set, the subscription that is expected to be provided during runtime.
	SubscriptionRuntimeOverridden string `` /* 150-byte string literal not displayed */
	// contains filtered or unexported fields
}

Payload used by Google Cloud Pub/Sub read transform. This can be used by runners that wish to override Beam Pub/Sub read transform with a native implementation. The SDK should guarantee that only one of topic, subscription, topic_runtime_overridden and subscription_runtime_overridden is set. The output of PubSubReadPayload should be bytes of serialized PubsubMessage proto if with_attributes == true. Otherwise, the bytes is the raw payload.

func (*PubSubReadPayload) Descriptor deprecated

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

Deprecated: Use PubSubReadPayload.ProtoReflect.Descriptor instead.

func (*PubSubReadPayload) GetIdAttribute

func (x *PubSubReadPayload) GetIdAttribute() string

func (*PubSubReadPayload) GetSubscription

func (x *PubSubReadPayload) GetSubscription() string

func (*PubSubReadPayload) GetSubscriptionRuntimeOverridden

func (x *PubSubReadPayload) GetSubscriptionRuntimeOverridden() string

func (*PubSubReadPayload) GetTimestampAttribute

func (x *PubSubReadPayload) GetTimestampAttribute() string

func (*PubSubReadPayload) GetTopic

func (x *PubSubReadPayload) GetTopic() string

func (*PubSubReadPayload) GetTopicRuntimeOverridden

func (x *PubSubReadPayload) GetTopicRuntimeOverridden() string

func (*PubSubReadPayload) GetWithAttributes

func (x *PubSubReadPayload) GetWithAttributes() bool

func (*PubSubReadPayload) ProtoMessage

func (*PubSubReadPayload) ProtoMessage()

func (*PubSubReadPayload) ProtoReflect

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

func (*PubSubReadPayload) Reset

func (x *PubSubReadPayload) Reset()

func (*PubSubReadPayload) String

func (x *PubSubReadPayload) String() string

type PubSubWritePayload

type PubSubWritePayload struct {

	// Topic to write to.
	// Topic format is: /topics/project_id/subscription_name
	Topic string `protobuf:"bytes,1,opt,name=topic,proto3" json:"topic,omitempty"`
	// Attribute that provides element timestamps.
	TimestampAttribute string `protobuf:"bytes,2,opt,name=timestamp_attribute,json=timestampAttribute,proto3" json:"timestamp_attribute,omitempty"`
	// Attribute that uniquely identify messages.
	IdAttribute string `protobuf:"bytes,3,opt,name=id_attribute,json=idAttribute,proto3" json:"id_attribute,omitempty"`
	// If set, the topic is expected to be provided during runtime.
	TopicRuntimeOverridden string `` /* 129-byte string literal not displayed */
	// contains filtered or unexported fields
}

Payload used by Google Cloud Pub/Sub write transform. This can be used by runners that wish to override Beam Pub/Sub write transform with a native implementation. The SDK should guarantee that only one of topic and topic_runtime_overridden is set. The output of PubSubWritePayload should be bytes if serialized PubsubMessage proto.

func (*PubSubWritePayload) Descriptor deprecated

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

Deprecated: Use PubSubWritePayload.ProtoReflect.Descriptor instead.

func (*PubSubWritePayload) GetIdAttribute

func (x *PubSubWritePayload) GetIdAttribute() string

func (*PubSubWritePayload) GetTimestampAttribute

func (x *PubSubWritePayload) GetTimestampAttribute() string

func (*PubSubWritePayload) GetTopic

func (x *PubSubWritePayload) GetTopic() string

func (*PubSubWritePayload) GetTopicRuntimeOverridden

func (x *PubSubWritePayload) GetTopicRuntimeOverridden() string

func (*PubSubWritePayload) ProtoMessage

func (*PubSubWritePayload) ProtoMessage()

func (*PubSubWritePayload) ProtoReflect

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

func (*PubSubWritePayload) Reset

func (x *PubSubWritePayload) Reset()

func (*PubSubWritePayload) String

func (x *PubSubWritePayload) String() string

type PyPIPayload

type PyPIPayload struct {

	// Pypi compatible artifact id e.g. "apache-beam"
	ArtifactId string `protobuf:"bytes,1,opt,name=artifact_id,json=artifactId,proto3" json:"artifact_id,omitempty"`
	// Pypi compatible version string.
	Version string `protobuf:"bytes,2,opt,name=version,proto3" json:"version,omitempty"`
	// contains filtered or unexported fields
}

func (*PyPIPayload) Descriptor deprecated

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

Deprecated: Use PyPIPayload.ProtoReflect.Descriptor instead.

func (*PyPIPayload) GetArtifactId

func (x *PyPIPayload) GetArtifactId() string

func (*PyPIPayload) GetVersion

func (x *PyPIPayload) GetVersion() string

func (*PyPIPayload) ProtoMessage

func (*PyPIPayload) ProtoMessage()

func (*PyPIPayload) ProtoReflect

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

func (*PyPIPayload) Reset

func (x *PyPIPayload) Reset()

func (*PyPIPayload) String

func (x *PyPIPayload) String() string

type ReadModifyWriteStateSpec

type ReadModifyWriteStateSpec struct {
	CoderId string `protobuf:"bytes,1,opt,name=coder_id,json=coderId,proto3" json:"coder_id,omitempty"`
	// contains filtered or unexported fields
}

func (*ReadModifyWriteStateSpec) Descriptor deprecated

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

Deprecated: Use ReadModifyWriteStateSpec.ProtoReflect.Descriptor instead.

func (*ReadModifyWriteStateSpec) GetCoderId

func (x *ReadModifyWriteStateSpec) GetCoderId() string

func (*ReadModifyWriteStateSpec) ProtoMessage

func (*ReadModifyWriteStateSpec) ProtoMessage()

func (*ReadModifyWriteStateSpec) ProtoReflect

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

func (*ReadModifyWriteStateSpec) Reset

func (x *ReadModifyWriteStateSpec) Reset()

func (*ReadModifyWriteStateSpec) String

func (x *ReadModifyWriteStateSpec) String() string

type ReadPayload

type ReadPayload struct {

	// (Required) The FunctionSpec of the source for this Read.
	Source *FunctionSpec `protobuf:"bytes,1,opt,name=source,proto3" json:"source,omitempty"`
	// (Required) Whether the source is bounded or unbounded
	IsBounded IsBounded_Enum `` /* 143-byte string literal not displayed */
	// contains filtered or unexported fields
}

The payload for the primitive Read transform.

func (*ReadPayload) Descriptor deprecated

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

Deprecated: Use ReadPayload.ProtoReflect.Descriptor instead.

func (*ReadPayload) GetIsBounded

func (x *ReadPayload) GetIsBounded() IsBounded_Enum

func (*ReadPayload) GetSource

func (x *ReadPayload) GetSource() *FunctionSpec

func (*ReadPayload) ProtoMessage

func (*ReadPayload) ProtoMessage()

func (*ReadPayload) ProtoReflect

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

func (*ReadPayload) Reset

func (x *ReadPayload) Reset()

func (*ReadPayload) String

func (x *ReadPayload) String() string

type Row

type Row struct {
	Values []*FieldValue `protobuf:"bytes,1,rep,name=values,proto3" json:"values,omitempty"`
	// contains filtered or unexported fields
}

func (*Row) Descriptor deprecated

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

Deprecated: Use Row.ProtoReflect.Descriptor instead.

func (*Row) GetValues

func (x *Row) GetValues() []*FieldValue

func (*Row) ProtoMessage

func (*Row) ProtoMessage()

func (*Row) ProtoReflect

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

func (*Row) Reset

func (x *Row) Reset()

func (*Row) String

func (x *Row) String() string

type RowType

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

func (*RowType) Descriptor deprecated

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

Deprecated: Use RowType.ProtoReflect.Descriptor instead.

func (*RowType) GetSchema

func (x *RowType) GetSchema() *Schema

func (*RowType) ProtoMessage

func (*RowType) ProtoMessage()

func (*RowType) ProtoReflect

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

func (*RowType) Reset

func (x *RowType) Reset()

func (*RowType) String

func (x *RowType) String() string

type Schema

type Schema struct {

	// List of fields for this schema. Two fields may not share a name.
	Fields []*Field `protobuf:"bytes,1,rep,name=fields,proto3" json:"fields,omitempty"`
	// REQUIRED. An RFC 4122 UUID.
	Id      string    `protobuf:"bytes,2,opt,name=id,proto3" json:"id,omitempty"`
	Options []*Option `protobuf:"bytes,3,rep,name=options,proto3" json:"options,omitempty"`
	// Indicates that encoding positions have been overridden.
	EncodingPositionsSet bool `protobuf:"varint,4,opt,name=encoding_positions_set,json=encodingPositionsSet,proto3" json:"encoding_positions_set,omitempty"`
	// contains filtered or unexported fields
}

func (*Schema) Descriptor deprecated

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

Deprecated: Use Schema.ProtoReflect.Descriptor instead.

func (*Schema) GetEncodingPositionsSet

func (x *Schema) GetEncodingPositionsSet() bool

func (*Schema) GetFields

func (x *Schema) GetFields() []*Field

func (*Schema) GetId

func (x *Schema) GetId() string

func (*Schema) GetOptions

func (x *Schema) GetOptions() []*Option

func (*Schema) ProtoMessage

func (*Schema) ProtoMessage()

func (*Schema) ProtoReflect

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

func (*Schema) Reset

func (x *Schema) Reset()

func (*Schema) String

func (x *Schema) String() string

type SessionWindowsPayload

type SessionWindowsPayload struct {

	// (Required) Minimum duration of gaps between sessions.
	GapSize *duration.Duration `protobuf:"bytes,1,opt,name=gap_size,json=gapSize,proto3" json:"gap_size,omitempty"`
	// contains filtered or unexported fields
}

A session window function defines windows that contain elements that are within a certain gap size of another element. Session windowing applies on a per-key basis and is useful for data that is irregularly distributed with respect to time. For example, a data stream representing user mouse activity may have long periods of idle time interspersed with high concentrations of clicks. If data arrives after the minimum specified gap size duration, this initiates the start of a new window.

See https://beam.apache.org/documentation/programming-guide/#session-windows for additional details.

func (*SessionWindowsPayload) Descriptor deprecated

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

Deprecated: Use SessionWindowsPayload.ProtoReflect.Descriptor instead.

func (*SessionWindowsPayload) GetGapSize

func (x *SessionWindowsPayload) GetGapSize() *duration.Duration

func (*SessionWindowsPayload) ProtoMessage

func (*SessionWindowsPayload) ProtoMessage()

func (*SessionWindowsPayload) ProtoReflect

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

func (*SessionWindowsPayload) Reset

func (x *SessionWindowsPayload) Reset()

func (*SessionWindowsPayload) String

func (x *SessionWindowsPayload) String() string

type SessionWindowsPayload_Enum

type SessionWindowsPayload_Enum int32
const (
	SessionWindowsPayload_PROPERTIES SessionWindowsPayload_Enum = 0
)

func (SessionWindowsPayload_Enum) Descriptor

func (SessionWindowsPayload_Enum) Enum

func (SessionWindowsPayload_Enum) EnumDescriptor deprecated

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

Deprecated: Use SessionWindowsPayload_Enum.Descriptor instead.

func (SessionWindowsPayload_Enum) Number

func (SessionWindowsPayload_Enum) String

func (SessionWindowsPayload_Enum) Type

type SetStateSpec

type SetStateSpec struct {
	ElementCoderId string `protobuf:"bytes,1,opt,name=element_coder_id,json=elementCoderId,proto3" json:"element_coder_id,omitempty"`
	// contains filtered or unexported fields
}

func (*SetStateSpec) Descriptor deprecated

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

Deprecated: Use SetStateSpec.ProtoReflect.Descriptor instead.

func (*SetStateSpec) GetElementCoderId

func (x *SetStateSpec) GetElementCoderId() string

func (*SetStateSpec) ProtoMessage

func (*SetStateSpec) ProtoMessage()

func (*SetStateSpec) ProtoReflect

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

func (*SetStateSpec) Reset

func (x *SetStateSpec) Reset()

func (*SetStateSpec) String

func (x *SetStateSpec) String() string

type SideInput

type SideInput struct {

	// (Required) URN of the access pattern required by the `view_fn` to present
	// the desired SDK-specific interface to a UDF.
	//
	// This access pattern defines the SDK harness <-> Runner Harness RPC
	// interface for accessing a side input.
	//
	// The only access pattern intended for Beam, because of its superior
	// performance possibilities, is "beam:sideinput:multimap" (or some such
	// URN)
	AccessPattern *FunctionSpec `protobuf:"bytes,1,opt,name=access_pattern,json=accessPattern,proto3" json:"access_pattern,omitempty"`
	// (Required) The FunctionSpec of the UDF that adapts a particular
	// access_pattern to a user-facing view type.
	//
	// For example, View.asSingleton() may include a `view_fn` that adapts a
	// specially-designed multimap to a single value per window.
	ViewFn *FunctionSpec `protobuf:"bytes,2,opt,name=view_fn,json=viewFn,proto3" json:"view_fn,omitempty"`
	// (Required) The FunctionSpec of the UDF that maps a main input window
	// to a side input window.
	//
	// For example, when the main input is in fixed windows of one hour, this
	// can specify that the side input should be accessed according to the day
	// in which that hour falls.
	WindowMappingFn *FunctionSpec `protobuf:"bytes,3,opt,name=window_mapping_fn,json=windowMappingFn,proto3" json:"window_mapping_fn,omitempty"`
	// contains filtered or unexported fields
}

A specification for how to "side input" a PCollection.

func (*SideInput) Descriptor deprecated

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

Deprecated: Use SideInput.ProtoReflect.Descriptor instead.

func (*SideInput) GetAccessPattern

func (x *SideInput) GetAccessPattern() *FunctionSpec

func (*SideInput) GetViewFn

func (x *SideInput) GetViewFn() *FunctionSpec

func (*SideInput) GetWindowMappingFn

func (x *SideInput) GetWindowMappingFn() *FunctionSpec

func (*SideInput) ProtoMessage

func (*SideInput) ProtoMessage()

func (*SideInput) ProtoReflect

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

func (*SideInput) Reset

func (x *SideInput) Reset()

func (*SideInput) String

func (x *SideInput) String() string

type SlidingWindowsPayload

type SlidingWindowsPayload struct {

	// (Required) Represents the size of the window.
	Size *duration.Duration `protobuf:"bytes,1,opt,name=size,proto3" json:"size,omitempty"`
	// (Required) Represents the timestamp of when the first window begins.
	// Window N will start at offset + N * period.
	Offset *timestamp.Timestamp `protobuf:"bytes,2,opt,name=offset,proto3" json:"offset,omitempty"`
	// (Required) Represents the amount of time between each start of a window.
	Period *duration.Duration `protobuf:"bytes,3,opt,name=period,proto3" json:"period,omitempty"`
	// contains filtered or unexported fields
}

A sliding time window represents time intervals in the data stream that can overlap. For example, each window might capture 60 seconds worth of data, but a new window starts every 30 seconds. The frequency with which sliding windows begin is called the period. Therefore, our example would have a window size of 60 seconds and a period of 30 seconds.

Because multiple windows overlap, most elements in a data set will belong to more than one window. This kind of windowing is useful for taking running averages of data; using sliding time windows, you can compute a running average of the past 60 seconds’ worth of data, updated every 30 seconds, in our example.

See https://beam.apache.org/documentation/programming-guide/#sliding-time-windows for additional details.

func (*SlidingWindowsPayload) Descriptor deprecated

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

Deprecated: Use SlidingWindowsPayload.ProtoReflect.Descriptor instead.

func (*SlidingWindowsPayload) GetOffset

func (x *SlidingWindowsPayload) GetOffset() *timestamp.Timestamp

func (*SlidingWindowsPayload) GetPeriod

func (x *SlidingWindowsPayload) GetPeriod() *duration.Duration

func (*SlidingWindowsPayload) GetSize

func (x *SlidingWindowsPayload) GetSize() *duration.Duration

func (*SlidingWindowsPayload) ProtoMessage

func (*SlidingWindowsPayload) ProtoMessage()

func (*SlidingWindowsPayload) ProtoReflect

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

func (*SlidingWindowsPayload) Reset

func (x *SlidingWindowsPayload) Reset()

func (*SlidingWindowsPayload) String

func (x *SlidingWindowsPayload) String() string

type SlidingWindowsPayload_Enum

type SlidingWindowsPayload_Enum int32
const (
	SlidingWindowsPayload_PROPERTIES SlidingWindowsPayload_Enum = 0
)

func (SlidingWindowsPayload_Enum) Descriptor

func (SlidingWindowsPayload_Enum) Enum

func (SlidingWindowsPayload_Enum) EnumDescriptor deprecated

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

Deprecated: Use SlidingWindowsPayload_Enum.Descriptor instead.

func (SlidingWindowsPayload_Enum) Number

func (SlidingWindowsPayload_Enum) String

func (SlidingWindowsPayload_Enum) Type

type StandardArtifacts

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

func (*StandardArtifacts) Descriptor deprecated

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

Deprecated: Use StandardArtifacts.ProtoReflect.Descriptor instead.

func (*StandardArtifacts) ProtoMessage

func (*StandardArtifacts) ProtoMessage()

func (*StandardArtifacts) ProtoReflect

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

func (*StandardArtifacts) Reset

func (x *StandardArtifacts) Reset()

func (*StandardArtifacts) String

func (x *StandardArtifacts) String() string

type StandardArtifacts_Roles

type StandardArtifacts_Roles int32
const (
	// A URN for staging-to role.
	// payload: ArtifactStagingToRolePayload
	StandardArtifacts_STAGING_TO StandardArtifacts_Roles = 0
	// A URN for pip-requirements-file role.
	// payload: None
	StandardArtifacts_PIP_REQUIREMENTS_FILE StandardArtifacts_Roles = 1
)

func (StandardArtifacts_Roles) Descriptor

func (StandardArtifacts_Roles) Enum

func (StandardArtifacts_Roles) EnumDescriptor deprecated

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

Deprecated: Use StandardArtifacts_Roles.Descriptor instead.

func (StandardArtifacts_Roles) Number

func (StandardArtifacts_Roles) String

func (x StandardArtifacts_Roles) String() string

func (StandardArtifacts_Roles) Type

type StandardArtifacts_Types

type StandardArtifacts_Types int32
const (
	// A URN for locally-accessible artifact files.
	// payload: ArtifactFilePayload
	StandardArtifacts_FILE StandardArtifacts_Types = 0
	// A URN for artifacts described by URLs.
	// payload: ArtifactUrlPayload
	StandardArtifacts_URL StandardArtifacts_Types = 1
	// A URN for artifacts embedded in ArtifactInformation proto.
	// payload: EmbeddedFilePayload.
	StandardArtifacts_EMBEDDED StandardArtifacts_Types = 2
	// A URN for Python artifacts hosted on PYPI.
	// payload: PypiPayload
	StandardArtifacts_PYPI StandardArtifacts_Types = 3
	// A URN for Java artifacts hosted on a Maven repository.
	// payload: MavenPayload
	StandardArtifacts_MAVEN StandardArtifacts_Types = 4
	// A URN for deferred artifacts.
	// payload: DeferredArtifactPayload
	StandardArtifacts_DEFERRED StandardArtifacts_Types = 5
)

func (StandardArtifacts_Types) Descriptor

func (StandardArtifacts_Types) Enum

func (StandardArtifacts_Types) EnumDescriptor deprecated

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

Deprecated: Use StandardArtifacts_Types.Descriptor instead.

func (StandardArtifacts_Types) Number

func (StandardArtifacts_Types) String

func (x StandardArtifacts_Types) String() string

func (StandardArtifacts_Types) Type

type StandardCoders

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

func (*StandardCoders) Descriptor deprecated

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

Deprecated: Use StandardCoders.ProtoReflect.Descriptor instead.

func (*StandardCoders) ProtoMessage

func (*StandardCoders) ProtoMessage()

func (*StandardCoders) ProtoReflect

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

func (*StandardCoders) Reset

func (x *StandardCoders) Reset()

func (*StandardCoders) String

func (x *StandardCoders) String() string

type StandardCoders_Enum

type StandardCoders_Enum int32
const (
	// Components: None
	StandardCoders_BYTES StandardCoders_Enum = 0
	// Components: None
	StandardCoders_STRING_UTF8 StandardCoders_Enum = 10
	// Components: The key and value coder, in that order.
	StandardCoders_KV StandardCoders_Enum = 1
	// Components: None
	StandardCoders_BOOL StandardCoders_Enum = 12
	// Variable length Encodes a 64-bit integer.
	// Components: None
	StandardCoders_VARINT StandardCoders_Enum = 2
	// Encodes the floating point value as a big-endian 64-bit integer
	// according to the IEEE 754 double format bit layout.
	// Components: None
	StandardCoders_DOUBLE StandardCoders_Enum = 11
	// Encodes an iterable of elements.
	//
	// The encoding for an iterable [e1...eN] of known length N is
	//
	//    fixed32(N)
	//    encode(e1) encode(e2) encode(e3) ... encode(eN)
	//
	// If the length is unknown, it is batched up into groups of size b1..bM
	// and encoded as
	//
	//     fixed32(-1)
	//     varInt64(b1) encode(e1) encode(e2) ... encode(e_b1)
	//     varInt64(b2) encode(e_(b1+1)) encode(e_(b1+2)) ... encode(e_(b1+b2))
	//     ...
	//     varInt64(bM) encode(e_(N-bM+1)) encode(e_(N-bM+2)) ... encode(eN)
	//     varInt64(0)
	//
	// Components: Coder for a single element.
	StandardCoders_ITERABLE StandardCoders_Enum = 3
	// Encodes a timer containing a user key, a dynamic timer tag, a clear bit,
	// a fire timestamp, a hold timestamp, the windows and the paneinfo.
	// The encoding is represented as:
	//   user key - user defined key, uses the component coder.
	//   dynamic timer tag - a string which identifies a timer.
	//   windows - uses component coders.
	//   clear bit - a boolean set for clearing the timer.
	//   fire timestamp - a big endian 8 byte integer representing millis-since-epoch.
	//     The encoded representation is shifted so that the byte representation of
	//     negative values are lexicographically ordered before the byte representation
	//     of positive values. This is typically done by subtracting -9223372036854775808
	//     from the value and encoding it as a signed big endian integer. Example values:
	//
	//     -9223372036854775808: 00 00 00 00 00 00 00 00
	//                     -255: 7F FF FF FF FF FF FF 01
	//                       -1: 7F FF FF FF FF FF FF FF
	//                        0: 80 00 00 00 00 00 00 00
	//                        1: 80 00 00 00 00 00 00 01
	//                      256: 80 00 00 00 00 00 01 00
	//      9223372036854775807: FF FF FF FF FF FF FF FF
	//   hold timestamp - similar to the fire timestamp.
	//   paneinfo - similar to the paneinfo of the windowed_value.
	// Components: Coder for the key and windows.
	StandardCoders_TIMER StandardCoders_Enum = 4
	// Components: None
	StandardCoders_INTERVAL_WINDOW StandardCoders_Enum = 5
	// Components: The coder to attach a length prefix to
	StandardCoders_LENGTH_PREFIX StandardCoders_Enum = 6
	// Components: None
	StandardCoders_GLOBAL_WINDOW StandardCoders_Enum = 7
	// Encodes an element, the windows it is in, the timestamp of the element,
	// and the pane of the element. The encoding is represented as:
	// timestamp windows pane element
	//   timestamp - A big endian 8 byte integer representing millis-since-epoch.
	//     The encoded representation is shifted so that the byte representation
	//     of negative values are lexicographically ordered before the byte
	//     representation of positive values. This is typically done by
	//     subtracting -9223372036854775808 from the value and encoding it as a
	//     signed big endian integer. Example values:
	//
	//     -9223372036854775808: 00 00 00 00 00 00 00 00
	//                     -255: 7F FF FF FF FF FF FF 01
	//                       -1: 7F FF FF FF FF FF FF FF
	//                        0: 80 00 00 00 00 00 00 00
	//                        1: 80 00 00 00 00 00 00 01
	//                      256: 80 00 00 00 00 00 01 00
	//      9223372036854775807: FF FF FF FF FF FF FF FF
	//
	//   windows - The windows are encoded using the beam:coder:iterable:v1
	//     format, where the windows are encoded using the supplied window
	//     coder.
	//
	//   pane - The first byte of the pane info determines which type of
	//     encoding is used, as well as the is_first, is_last, and timing
	//     fields. If this byte is bits [0 1 2 3 4 5 6 7], then:
	//     * bits [0 1 2 3] determine the encoding as follows:
	//         0000 - The entire pane info is encoded as a single byte.
	//                The is_first, is_last, and timing fields are encoded
	//                as below, and the index and non-speculative index are
	//                both zero (and hence are not encoded here).
	//         0001 - The pane info is encoded as this byte plus a single
	//                VarInt encoed integer representing the pane index. The
	//                non-speculative index can be derived as follows:
	//                  -1 if the pane is early, otherwise equal to index.
	//         0010 - The pane info is encoded as this byte plus two VarInt
	//                encoded integers representing the pane index and
	//                non-speculative index respectively.
	//     * bits [4 5] encode the timing as follows:
	//         00 - early
	//         01 - on time
	//         10 - late
	//         11 - unknown
	//     * bit 6 is 1 if this is the first pane, 0 otherwise.
	//     * bit 7 is 1 if this is the last pane, 0 otherwise.
	//
	//   element - The element incoded using the supplied element coder.
	//
	// Components: The element coder and the window coder, in that order.
	StandardCoders_WINDOWED_VALUE StandardCoders_Enum = 8
	// A windowed value coder with parameterized timestamp, windows and pane info.
	// Encodes an element with only the value of the windowed value.
	// Decodes the value and assigns the parameterized timestamp, windows and pane info to the
	// windowed value.
	// Components: The element coder and the window coder, in that order
	// The payload of this coder is an encoded windowed value using the
	// beam:coder:windowed_value:v1 coder parameterized by a beam:coder:bytes:v1
	// element coder and the window coder that this param_windowed_value coder uses.
	StandardCoders_PARAM_WINDOWED_VALUE StandardCoders_Enum = 14
	// Encodes an iterable of elements, some of which may be stored elsewhere.
	//
	// The encoding for a state-backed iterable is the same as that for
	// an iterable, but the final varInt64(0) terminating the set of batches
	// may instead be replaced by
	//
	//     varInt64(-1)
	//     varInt64(len(token))
	//     token
	//
	// where token is an opaque byte string that can be used to fetch the
	// remainder of the iterable (e.g. over the state API).
	//
	// Components: Coder for a single element.
	// Experimental.
	StandardCoders_STATE_BACKED_ITERABLE StandardCoders_Enum = 9
	// Encodes a "row", an element with a known schema, defined by an
	// instance of Schema from schema.proto.
	//
	// A row is encoded as the concatenation of:
	//   - The number of attributes in the schema, encoded with
	//     beam:coder:varint:v1. This makes it possible to detect certain
	//     allowed schema changes (appending or removing columns) in
	//     long-running streaming pipelines.
	//   - A byte array representing a packed bitset indicating null fields (a
	//     1 indicating a null) encoded with beam:coder:bytes:v1. The unused
	//     bits in the last byte must be set to 0. If there are no nulls an
	//     empty byte array is encoded.
	//     The two-byte bitset (not including the lenghth-prefix) for the row
	//     [NULL, 0, 0, 0, NULL, 0, 0, NULL, 0, NULL] would be
	//     [0b10010001, 0b00000010]
	//   - An encoding for each non-null field, concatenated together.
	//
	// Schema types are mapped to coders as follows:
	//   AtomicType:
	//     BYTE:      not yet a standard coder (BEAM-7996)
	//     INT16:     not yet a standard coder (BEAM-7996)
	//     INT32:     beam:coder:varint:v1
	//     INT64:     beam:coder:varint:v1
	//     FLOAT:     not yet a standard coder (BEAM-7996)
	//     DOUBLE:    beam:coder:double:v1
	//     STRING:    beam:coder:string_utf8:v1
	//     BOOLEAN:   beam:coder:bool:v1
	//     BYTES:     beam:coder:bytes:v1
	//   ArrayType:   beam:coder:iterable:v1 (always has a known length)
	//   MapType:     not a standard coder, specification defined below.
	//   RowType:     beam:coder:row:v1
	//   LogicalType: Uses the coder for its representation.
	//
	// The MapType is encoded by:
	//   - An INT32 representing the size of the map (N)
	//   - Followed by N interleaved keys and values, encoded with their
	//     corresponding coder.
	//
	// Nullable types in container types (ArrayType, MapType) are encoded by:
	//   - A one byte null indicator, 0x00 for null values, or 0x01 for present
	//     values.
	//   - For present values the null indicator is followed by the value
	//     encoded with it's corresponding coder.
	//
	// Well known logical types:
	//   beam:logical_type:micros_instant:v1
	//   - Representation type: ROW<seconds: INT64, micros: INT64>
	//   - A timestamp without a timezone where seconds + micros represents the
	//     amount of time since the epoch.
	//
	// The payload for RowCoder is an instance of Schema.
	// Components: None
	// Experimental.
	StandardCoders_ROW StandardCoders_Enum = 13
	// Encodes a user key and a shard id which is an opaque byte string.
	//
	// The encoding for a sharded key consists of a shard id byte string and the
	// encoded user key in the following order:
	//
	//     - shard id using beam:coder:bytes:v1
	//     - encoded user key
	//
	// Examples:
	// user key with an empty shard id
	//     0x00
	//     encode(user_key)
	//
	// user key with a shard id taking up two bytes.
	//     0x02
	//     0x11 0x22
	//     encode(user_key)
	//
	// Components: the user key coder.
	// Experimental.
	StandardCoders_SHARDED_KEY StandardCoders_Enum = 15
)

func (StandardCoders_Enum) Descriptor

func (StandardCoders_Enum) Enum

func (StandardCoders_Enum) EnumDescriptor deprecated

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

Deprecated: Use StandardCoders_Enum.Descriptor instead.

func (StandardCoders_Enum) Number

func (StandardCoders_Enum) String

func (x StandardCoders_Enum) String() string

func (StandardCoders_Enum) Type

type StandardDisplayData

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

A set of well known URNs describing display data.

All descriptions must contain how the value should be classified and how it is encoded. Note that some types are logical types which convey contextual information about the pipeline in addition to an encoding while others only specify the encoding itself.

func (*StandardDisplayData) Descriptor deprecated

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

Deprecated: Use StandardDisplayData.ProtoReflect.Descriptor instead.

func (*StandardDisplayData) ProtoMessage

func (*StandardDisplayData) ProtoMessage()

func (*StandardDisplayData) ProtoReflect

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

func (*StandardDisplayData) Reset

func (x *StandardDisplayData) Reset()

func (*StandardDisplayData) String

func (x *StandardDisplayData) String() string

type StandardDisplayData_DisplayData

type StandardDisplayData_DisplayData int32
const (
	// A string label and value. Has a payload containing an encoded
	// LabelledPayload.
	StandardDisplayData_LABELLED StandardDisplayData_DisplayData = 0
)

func (StandardDisplayData_DisplayData) Descriptor

func (StandardDisplayData_DisplayData) Enum

func (StandardDisplayData_DisplayData) EnumDescriptor deprecated

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

Deprecated: Use StandardDisplayData_DisplayData.Descriptor instead.

func (StandardDisplayData_DisplayData) Number

func (StandardDisplayData_DisplayData) String

func (StandardDisplayData_DisplayData) Type

type StandardEnvironments

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

func (*StandardEnvironments) Descriptor deprecated

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

Deprecated: Use StandardEnvironments.ProtoReflect.Descriptor instead.

func (*StandardEnvironments) ProtoMessage

func (*StandardEnvironments) ProtoMessage()

func (*StandardEnvironments) ProtoReflect

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

func (*StandardEnvironments) Reset

func (x *StandardEnvironments) Reset()

func (*StandardEnvironments) String

func (x *StandardEnvironments) String() string

type StandardEnvironments_Environments

type StandardEnvironments_Environments int32
const (
	StandardEnvironments_DOCKER   StandardEnvironments_Environments = 0 // A managed docker container to run user code.
	StandardEnvironments_PROCESS  StandardEnvironments_Environments = 1 // A managed native process to run user code.
	StandardEnvironments_EXTERNAL StandardEnvironments_Environments = 2 // An external non managed process to run user code.
	StandardEnvironments_DEFAULT  StandardEnvironments_Environments = 3 // Used as a stub when context is missing a runner-provided default environment.
)

func (StandardEnvironments_Environments) Descriptor

func (StandardEnvironments_Environments) Enum

func (StandardEnvironments_Environments) EnumDescriptor deprecated

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

Deprecated: Use StandardEnvironments_Environments.Descriptor instead.

func (StandardEnvironments_Environments) Number

func (StandardEnvironments_Environments) String

func (StandardEnvironments_Environments) Type

type StandardPTransforms

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

func (*StandardPTransforms) Descriptor deprecated

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

Deprecated: Use StandardPTransforms.ProtoReflect.Descriptor instead.

func (*StandardPTransforms) ProtoMessage

func (*StandardPTransforms) ProtoMessage()

func (*StandardPTransforms) ProtoReflect

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

func (*StandardPTransforms) Reset

func (x *StandardPTransforms) Reset()

func (*StandardPTransforms) String

func (x *StandardPTransforms) String() string

type StandardPTransforms_CombineComponents

type StandardPTransforms_CombineComponents int32

Payload for all of these: CombinePayload

const (
	// Represents the Pre-Combine part of a lifted Combine Per Key, as described
	// in the following document:
	// https://s.apache.org/beam-runner-api-combine-model#heading=h.ta0g6ase8z07
	// Payload: CombinePayload
	StandardPTransforms_COMBINE_PER_KEY_PRECOMBINE StandardPTransforms_CombineComponents = 0
	// Represents the Merge Accumulators part of a lifted Combine Per Key, as
	// described in the following document:
	// https://s.apache.org/beam-runner-api-combine-model#heading=h.jco9rvatld5m
	// Payload: CombinePayload
	StandardPTransforms_COMBINE_PER_KEY_MERGE_ACCUMULATORS StandardPTransforms_CombineComponents = 1
	// Represents the Extract Outputs part of a lifted Combine Per Key, as
	// described in the following document:
	// https://s.apache.org/beam-runner-api-combine-model#heading=h.i9i6p8gtl6ku
	// Payload: CombinePayload
	StandardPTransforms_COMBINE_PER_KEY_EXTRACT_OUTPUTS StandardPTransforms_CombineComponents = 2
	// Represents the Combine Grouped Values transform, as described in the
	// following document:
	// https://s.apache.org/beam-runner-api-combine-model#heading=h.aj86ew4v1wk
	// Payload: CombinePayload
	StandardPTransforms_COMBINE_GROUPED_VALUES StandardPTransforms_CombineComponents = 3
	// Represents the Convert To Accumulators transform, as described in the
	// following document:
	// https://s.apache.org/beam-runner-api-combine-model#heading=h.h5697l1scd9x
	// Payload: CombinePayload
	StandardPTransforms_COMBINE_PER_KEY_CONVERT_TO_ACCUMULATORS StandardPTransforms_CombineComponents = 4
)

func (StandardPTransforms_CombineComponents) Descriptor

func (StandardPTransforms_CombineComponents) Enum

func (StandardPTransforms_CombineComponents) EnumDescriptor deprecated

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

Deprecated: Use StandardPTransforms_CombineComponents.Descriptor instead.

func (StandardPTransforms_CombineComponents) Number

func (StandardPTransforms_CombineComponents) String

func (StandardPTransforms_CombineComponents) Type

type StandardPTransforms_Composites

type StandardPTransforms_Composites int32
const (
	// Represents the Combine.perKey() operation.
	// If this is produced by an SDK, it is assumed that the SDK understands
	// each of CombineComponents.
	// Payload: CombinePayload
	StandardPTransforms_COMBINE_PER_KEY StandardPTransforms_Composites = 0
	// Represents the Combine.globally() operation.
	// If this is produced by an SDK, it is assumed that the SDK understands
	// each of CombineComponents.
	// Payload: CombinePayload
	StandardPTransforms_COMBINE_GLOBALLY StandardPTransforms_Composites = 1
	// Represents the Reshuffle operation.
	StandardPTransforms_RESHUFFLE StandardPTransforms_Composites = 2
	// Less well-known. Payload: WriteFilesPayload.
	StandardPTransforms_WRITE_FILES StandardPTransforms_Composites = 3
	// Payload: PubSubReadPayload.
	StandardPTransforms_PUBSUB_READ StandardPTransforms_Composites = 4
	// Payload: PubSubWritePayload.
	StandardPTransforms_PUBSUB_WRITE StandardPTransforms_Composites = 5
	// Represents the GroupIntoBatches.WithShardedKey operation.
	// Payload: GroupIntoBatchesPayload
	StandardPTransforms_GROUP_INTO_BATCHES_WITH_SHARDED_KEY StandardPTransforms_Composites = 6
)

func (StandardPTransforms_Composites) Descriptor

func (StandardPTransforms_Composites) Enum

func (StandardPTransforms_Composites) EnumDescriptor deprecated

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

Deprecated: Use StandardPTransforms_Composites.Descriptor instead.

func (StandardPTransforms_Composites) Number

func (StandardPTransforms_Composites) String

func (StandardPTransforms_Composites) Type

type StandardPTransforms_DeprecatedPrimitives

type StandardPTransforms_DeprecatedPrimitives int32
const (
	// Represents the operation to read a Bounded or Unbounded source.
	// Payload: ReadPayload.
	StandardPTransforms_READ StandardPTransforms_DeprecatedPrimitives = 0
	// Runners should move away from translating `CreatePCollectionView` and treat this as
	// part of the translation for a `ParDo` side input.
	StandardPTransforms_CREATE_VIEW StandardPTransforms_DeprecatedPrimitives = 1
)

func (StandardPTransforms_DeprecatedPrimitives) Descriptor

func (StandardPTransforms_DeprecatedPrimitives) Enum

func (StandardPTransforms_DeprecatedPrimitives) EnumDescriptor deprecated

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

Deprecated: Use StandardPTransforms_DeprecatedPrimitives.Descriptor instead.

func (StandardPTransforms_DeprecatedPrimitives) Number

func (StandardPTransforms_DeprecatedPrimitives) String

func (StandardPTransforms_DeprecatedPrimitives) Type

type StandardPTransforms_GroupIntoBatchesComponents

type StandardPTransforms_GroupIntoBatchesComponents int32

Payload for all of these: GroupIntoBatchesPayload

const (
	StandardPTransforms_GROUP_INTO_BATCHES StandardPTransforms_GroupIntoBatchesComponents = 0
)

func (StandardPTransforms_GroupIntoBatchesComponents) Descriptor

func (StandardPTransforms_GroupIntoBatchesComponents) Enum

func (StandardPTransforms_GroupIntoBatchesComponents) EnumDescriptor deprecated

Deprecated: Use StandardPTransforms_GroupIntoBatchesComponents.Descriptor instead.

func (StandardPTransforms_GroupIntoBatchesComponents) Number

func (StandardPTransforms_GroupIntoBatchesComponents) String

func (StandardPTransforms_GroupIntoBatchesComponents) Type

type StandardPTransforms_Primitives

type StandardPTransforms_Primitives int32

Primitive transforms may not specify composite sub-transforms.

const (
	// ParDo is a Beam transform for generic parallel processing. The ParDo
	// processing paradigm is similar to the “Map” phase of a
	// Map/Shuffle/Reduce-style algorithm: a ParDo transform considers each
	// element in the input PCollection, performs some processing function
	// (your user code) on that element, and emits zero, one, or multiple
	// elements to an output PCollection.
	//
	// See https://beam.apache.org/documentation/programming-guide/#pardo
	// for additional details.
	//
	// Payload: ParDoPayload
	StandardPTransforms_PAR_DO StandardPTransforms_Primitives = 0
	// Flatten is a Beam transform for PCollection objects that store the same
	// data type. Flatten merges multiple PCollection objects into a single
	// logical PCollection.
	//
	// See https://beam.apache.org/documentation/programming-guide/#flatten
	// for additional details.
	//
	// Payload: None
	StandardPTransforms_FLATTEN StandardPTransforms_Primitives = 1
	// GroupByKey is a Beam transform for processing collections of key/value
	// pairs. It’s a parallel reduction operation, analogous to the Shuffle
	// phase of a Map/Shuffle/Reduce-style algorithm. The input to GroupByKey is
	// a collection of key/value pairs that represents a multimap, where the
	// collection contains multiple pairs that have the same key, but different
	// values. Given such a collection, you use GroupByKey to collect all of the
	// values associated with each unique key.
	//
	// See https://beam.apache.org/documentation/programming-guide/#groupbykey
	// for additional details.
	//
	// Never defines an environment as the runner is required to implement this
	// transform.
	//
	// Payload: None
	StandardPTransforms_GROUP_BY_KEY StandardPTransforms_Primitives = 2
	// A transform which produces a single empty byte array at the minimum
	// timestamp in the GlobalWindow.
	//
	// Never defines an environment as the runner is required to implement this
	// transform.
	//
	// Payload: None
	StandardPTransforms_IMPULSE StandardPTransforms_Primitives = 3
	// Windowing subdivides a PCollection according to the timestamps of its
	// individual elements. Transforms that aggregate multiple elements, such as
	// GroupByKey and Combine, work implicitly on a per-window basis — they
	// process each PCollection as a succession of multiple, finite windows,
	// though the entire collection itself may be of unbounded size.
	//
	// See https://beam.apache.org/documentation/programming-guide/#windowing
	// for additional details.
	//
	// Payload: WindowIntoPayload
	StandardPTransforms_ASSIGN_WINDOWS StandardPTransforms_Primitives = 4
	// A testing input that generates an unbounded {@link PCollection} of
	// elements, advancing the watermark and processing time as elements are
	// emitted. After all of the specified elements are emitted, ceases to
	// produce output.
	//
	// See https://beam.apache.org/blog/2016/10/20/test-stream.html
	// for additional details.
	//
	// Payload: TestStreamPayload
	StandardPTransforms_TEST_STREAM StandardPTransforms_Primitives = 5
	// Represents mapping of main input window onto side input window.
	//
	// Side input window mapping function:
	// Input: KV<nonce, MainInputWindow>
	// Output: KV<nonce, SideInputWindow>
	//
	// For each main input window, the side input window is returned. The
	// nonce is used by a runner to associate each input with its output.
	// The nonce is represented as an opaque set of bytes.
	//
	// Payload: SideInput#window_mapping_fn FunctionSpec
	StandardPTransforms_MAP_WINDOWS StandardPTransforms_Primitives = 6
	// Used to merge windows during a GroupByKey.
	//
	// Window merging function:
	// Input: KV<nonce, iterable<OriginalWindow>>
	// Output: KV<nonce, KV<iterable<UnmergedOriginalWindow>, iterable<KV<MergedWindow, iterable<ConsumedOriginalWindow>>>>
	//
	// For each set of original windows, a list of all unmerged windows is
	// output alongside a map of merged window to set of consumed windows.
	// All original windows must be contained in either the unmerged original
	// window set or one of the consumed original window sets. Each original
	// window can only be part of one output set. The nonce is used by a runner
	// to associate each input with its output. The nonce is represented as an
	// opaque set of bytes.
	//
	// Payload: WindowingStrategy#window_fn FunctionSpec
	StandardPTransforms_MERGE_WINDOWS StandardPTransforms_Primitives = 7
	// A transform that translates a given element to its human-readable
	// representation.
	//
	// Input: KV<nonce, element>
	// Output: KV<nonce, string>
	//
	// For each given element, the implementation returns the best-effort
	// human-readable representation. When possible, the implementation could
	// call a user-overridable method on the type. For example, Java could
	// call `toString()`, Python could call `str()`, Golang could call
	// `String()`.  The nonce is used by a runner to associate each input with
	// its output. The nonce is represented as an opaque set of bytes.
	//
	// Payload: none
	StandardPTransforms_TO_STRING StandardPTransforms_Primitives = 8
)

func (StandardPTransforms_Primitives) Descriptor

func (StandardPTransforms_Primitives) Enum

func (StandardPTransforms_Primitives) EnumDescriptor deprecated

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

Deprecated: Use StandardPTransforms_Primitives.Descriptor instead.

func (StandardPTransforms_Primitives) Number

func (StandardPTransforms_Primitives) String

func (StandardPTransforms_Primitives) Type

type StandardPTransforms_SplittableParDoComponents

type StandardPTransforms_SplittableParDoComponents int32

Payload for all of these: ParDoPayload containing the user's SDF

const (
	// Pairs the input element with its initial restriction.
	// Input: element; output: KV(element, restriction).
	StandardPTransforms_PAIR_WITH_RESTRICTION StandardPTransforms_SplittableParDoComponents = 0
	// Splits the restriction of each element/restriction pair and returns the
	// resulting splits, with a corresponding floating point size estimation
	// for each.
	//
	// A reasonable value for size is the number of bytes expected to be
	// produced by this (element, restriction) pair.
	//
	// Input: KV(element, restriction)
	// Output: KV(KV(element, restriction), size))
	StandardPTransforms_SPLIT_AND_SIZE_RESTRICTIONS StandardPTransforms_SplittableParDoComponents = 1
	// Applies the DoFn to every element and restriction.
	//
	// All primary and residuals returned from checkpointing or splitting must
	// have the same type as the input to this transform.
	//
	// Input: KV(KV(element, restriction), size); output: DoFn's output.
	StandardPTransforms_PROCESS_SIZED_ELEMENTS_AND_RESTRICTIONS StandardPTransforms_SplittableParDoComponents = 2
	// Truncates the restriction of each element/restriction pair and returns
	// the finite restriction which will be processed when a pipeline is
	// drained. See
	// https://docs.google.com/document/d/1NExwHlj-2q2WUGhSO4jTu8XGhDPmm3cllSN8IMmWci8/edit#.
	// for additional details about drain.
	//
	// Input: KV(KV(element, restriction), size);
	// Output: KV(KV(element, restriction), size).
	StandardPTransforms_TRUNCATE_SIZED_RESTRICTION StandardPTransforms_SplittableParDoComponents = 3
)

func (StandardPTransforms_SplittableParDoComponents) Descriptor

func (StandardPTransforms_SplittableParDoComponents) Enum

func (StandardPTransforms_SplittableParDoComponents) EnumDescriptor deprecated

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

Deprecated: Use StandardPTransforms_SplittableParDoComponents.Descriptor instead.

func (StandardPTransforms_SplittableParDoComponents) Number

func (StandardPTransforms_SplittableParDoComponents) String

func (StandardPTransforms_SplittableParDoComponents) Type

type StandardProtocols

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

These URNs are used to indicate capabilities of environments that cannot simply be expressed as a component (such as a Coder or PTransform) that this environment understands.

func (*StandardProtocols) Descriptor deprecated

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

Deprecated: Use StandardProtocols.ProtoReflect.Descriptor instead.

func (*StandardProtocols) ProtoMessage

func (*StandardProtocols) ProtoMessage()

func (*StandardProtocols) ProtoReflect

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

func (*StandardProtocols) Reset

func (x *StandardProtocols) Reset()

func (*StandardProtocols) String

func (x *StandardProtocols) String() string

type StandardProtocols_Enum

type StandardProtocols_Enum int32
const (
	// Indicates suport for progress reporting via the legacy Metrics proto.
	StandardProtocols_LEGACY_PROGRESS_REPORTING StandardProtocols_Enum = 0
	// Indicates suport for progress reporting via the new MonitoringInfo proto.
	StandardProtocols_PROGRESS_REPORTING StandardProtocols_Enum = 1
	// Indicates suport for worker status protocol defined at
	// https://s.apache.org/beam-fn-api-harness-status.
	StandardProtocols_WORKER_STATUS StandardProtocols_Enum = 2
	// Indicates this SDK can take advantage of multiple cores when processing
	// concurrent process bundle requests. (Note that all SDKs must process
	// an unbounded number of concurrent process bundle requests; this capability
	// simply indicates this SDK can actually parallelize the work across multiple
	// cores.
	StandardProtocols_MULTI_CORE_BUNDLE_PROCESSING StandardProtocols_Enum = 3
	// Indicates that this SDK handles the InstructionRequest of type
	// HarnessMonitoringInfosRequest.
	// A request to provide full MonitoringInfo data associated with
	// the entire SDK harness process, not specific to a bundle.
	StandardProtocols_HARNESS_MONITORING_INFOS StandardProtocols_Enum = 4
)

func (StandardProtocols_Enum) Descriptor

func (StandardProtocols_Enum) Enum

func (StandardProtocols_Enum) EnumDescriptor deprecated

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

Deprecated: Use StandardProtocols_Enum.Descriptor instead.

func (StandardProtocols_Enum) Number

func (StandardProtocols_Enum) String

func (x StandardProtocols_Enum) String() string

func (StandardProtocols_Enum) Type

type StandardRequirements

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

These URNs are used to indicate requirements of a pipeline that cannot simply be expressed as a component (such as a Coder or PTransform) that the runner must understand. In many cases, this indicates a particular field of a transform must be inspected and respected (which allows new fields to be added in a forwards-compatible way).

func (*StandardRequirements) Descriptor deprecated

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

Deprecated: Use StandardRequirements.ProtoReflect.Descriptor instead.

func (*StandardRequirements) ProtoMessage

func (*StandardRequirements) ProtoMessage()

func (*StandardRequirements) ProtoReflect

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

func (*StandardRequirements) Reset

func (x *StandardRequirements) Reset()

func (*StandardRequirements) String

func (x *StandardRequirements) String() string

type StandardRequirements_Enum

type StandardRequirements_Enum int32
const (
	// This requirement indicates the state_spec and time_spec fields of ParDo
	// transform payloads must be inspected.
	StandardRequirements_REQUIRES_STATEFUL_PROCESSING StandardRequirements_Enum = 0
	// This requirement indicates the requests_finalization field of ParDo
	// transform payloads must be inspected.
	StandardRequirements_REQUIRES_BUNDLE_FINALIZATION StandardRequirements_Enum = 1
	// This requirement indicates the requires_stable_input field of ParDo
	// transform payloads must be inspected.
	StandardRequirements_REQUIRES_STABLE_INPUT StandardRequirements_Enum = 2
	// This requirement indicates the requires_time_sorted_input field of ParDo
	// transform payloads must be inspected.
	StandardRequirements_REQUIRES_TIME_SORTED_INPUT StandardRequirements_Enum = 3
	// This requirement indicates the restriction_coder_id field of ParDo
	// transform payloads must be inspected.
	StandardRequirements_REQUIRES_SPLITTABLE_DOFN StandardRequirements_Enum = 4
)

func (StandardRequirements_Enum) Descriptor

func (StandardRequirements_Enum) Enum

func (StandardRequirements_Enum) EnumDescriptor deprecated

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

Deprecated: Use StandardRequirements_Enum.Descriptor instead.

func (StandardRequirements_Enum) Number

func (StandardRequirements_Enum) String

func (x StandardRequirements_Enum) String() string

func (StandardRequirements_Enum) Type

type StandardResourceHints

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

func (*StandardResourceHints) Descriptor deprecated

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

Deprecated: Use StandardResourceHints.ProtoReflect.Descriptor instead.

func (*StandardResourceHints) ProtoMessage

func (*StandardResourceHints) ProtoMessage()

func (*StandardResourceHints) ProtoReflect

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

func (*StandardResourceHints) Reset

func (x *StandardResourceHints) Reset()

func (*StandardResourceHints) String

func (x *StandardResourceHints) String() string

type StandardResourceHints_Enum

type StandardResourceHints_Enum int32
const (
	// Describes hardware accelerators that are desired to have in the execution environment.
	StandardResourceHints_ACCELERATOR StandardResourceHints_Enum = 0
	// Describes desired minimal available RAM size in transform's execution environment.
	// SDKs should convert the size to bytes, but can allow users to specify human-friendly units (e.g. GiB).
	StandardResourceHints_MIN_RAM_BYTES StandardResourceHints_Enum = 1
)

func (StandardResourceHints_Enum) Descriptor

func (StandardResourceHints_Enum) Enum

func (StandardResourceHints_Enum) EnumDescriptor deprecated

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

Deprecated: Use StandardResourceHints_Enum.Descriptor instead.

func (StandardResourceHints_Enum) Number

func (StandardResourceHints_Enum) String

func (StandardResourceHints_Enum) Type

type StandardRunnerProtocols

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

These URNs are used to indicate capabilities of runner that an environment may take advantage of when interacting with this runner.

func (*StandardRunnerProtocols) Descriptor deprecated

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

Deprecated: Use StandardRunnerProtocols.ProtoReflect.Descriptor instead.

func (*StandardRunnerProtocols) ProtoMessage

func (*StandardRunnerProtocols) ProtoMessage()

func (*StandardRunnerProtocols) ProtoReflect

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

func (*StandardRunnerProtocols) Reset

func (x *StandardRunnerProtocols) Reset()

func (*StandardRunnerProtocols) String

func (x *StandardRunnerProtocols) String() string

type StandardRunnerProtocols_Enum

type StandardRunnerProtocols_Enum int32
const (
	// Indicates suport the MonitoringInfo short id protocol.
	StandardRunnerProtocols_MONITORING_INFO_SHORT_IDS StandardRunnerProtocols_Enum = 0
)

func (StandardRunnerProtocols_Enum) Descriptor

func (StandardRunnerProtocols_Enum) Enum

func (StandardRunnerProtocols_Enum) EnumDescriptor deprecated

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

Deprecated: Use StandardRunnerProtocols_Enum.Descriptor instead.

func (StandardRunnerProtocols_Enum) Number

func (StandardRunnerProtocols_Enum) String

func (StandardRunnerProtocols_Enum) Type

type StandardSideInputTypes

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

func (*StandardSideInputTypes) Descriptor deprecated

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

Deprecated: Use StandardSideInputTypes.ProtoReflect.Descriptor instead.

func (*StandardSideInputTypes) ProtoMessage

func (*StandardSideInputTypes) ProtoMessage()

func (*StandardSideInputTypes) ProtoReflect

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

func (*StandardSideInputTypes) Reset

func (x *StandardSideInputTypes) Reset()

func (*StandardSideInputTypes) String

func (x *StandardSideInputTypes) String() string

type StandardSideInputTypes_Enum

type StandardSideInputTypes_Enum int32
const (
	// Represents a view over a PCollection<V>.
	//
	// StateGetRequests performed on this side input must use
	// StateKey.IterableSideInput.
	StandardSideInputTypes_ITERABLE StandardSideInputTypes_Enum = 0
	// Represents a view over a PCollection<KV<K, V>>.
	//
	// StateGetRequests performed on this side input must use
	// StateKey.IterableSideInput or StateKey.MultimapSideInput.
	StandardSideInputTypes_MULTIMAP StandardSideInputTypes_Enum = 1
)

func (StandardSideInputTypes_Enum) Descriptor

func (StandardSideInputTypes_Enum) Enum

func (StandardSideInputTypes_Enum) EnumDescriptor deprecated

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

Deprecated: Use StandardSideInputTypes_Enum.Descriptor instead.

func (StandardSideInputTypes_Enum) Number

func (StandardSideInputTypes_Enum) String

func (StandardSideInputTypes_Enum) Type

type StateSpec

type StateSpec struct {

	// Types that are assignable to Spec:
	//	*StateSpec_ReadModifyWriteSpec
	//	*StateSpec_BagSpec
	//	*StateSpec_CombiningSpec
	//	*StateSpec_MapSpec
	//	*StateSpec_SetSpec
	//	*StateSpec_OrderedListSpec
	Spec isStateSpec_Spec `protobuf_oneof:"spec"`
	// contains filtered or unexported fields
}

func (*StateSpec) Descriptor deprecated

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

Deprecated: Use StateSpec.ProtoReflect.Descriptor instead.

func (*StateSpec) GetBagSpec

func (x *StateSpec) GetBagSpec() *BagStateSpec

func (*StateSpec) GetCombiningSpec

func (x *StateSpec) GetCombiningSpec() *CombiningStateSpec

func (*StateSpec) GetMapSpec

func (x *StateSpec) GetMapSpec() *MapStateSpec

func (*StateSpec) GetOrderedListSpec

func (x *StateSpec) GetOrderedListSpec() *OrderedListStateSpec

func (*StateSpec) GetReadModifyWriteSpec

func (x *StateSpec) GetReadModifyWriteSpec() *ReadModifyWriteStateSpec

func (*StateSpec) GetSetSpec

func (x *StateSpec) GetSetSpec() *SetStateSpec

func (*StateSpec) GetSpec

func (m *StateSpec) GetSpec() isStateSpec_Spec

func (*StateSpec) ProtoMessage

func (*StateSpec) ProtoMessage()

func (*StateSpec) ProtoReflect

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

func (*StateSpec) Reset

func (x *StateSpec) Reset()

func (*StateSpec) String

func (x *StateSpec) String() string

type StateSpec_BagSpec

type StateSpec_BagSpec struct {
	BagSpec *BagStateSpec `protobuf:"bytes,2,opt,name=bag_spec,json=bagSpec,proto3,oneof"`
}

type StateSpec_CombiningSpec

type StateSpec_CombiningSpec struct {
	CombiningSpec *CombiningStateSpec `protobuf:"bytes,3,opt,name=combining_spec,json=combiningSpec,proto3,oneof"`
}

type StateSpec_MapSpec

type StateSpec_MapSpec struct {
	MapSpec *MapStateSpec `protobuf:"bytes,4,opt,name=map_spec,json=mapSpec,proto3,oneof"`
}

type StateSpec_OrderedListSpec

type StateSpec_OrderedListSpec struct {
	OrderedListSpec *OrderedListStateSpec `protobuf:"bytes,6,opt,name=ordered_list_spec,json=orderedListSpec,proto3,oneof"`
}

type StateSpec_ReadModifyWriteSpec

type StateSpec_ReadModifyWriteSpec struct {
	ReadModifyWriteSpec *ReadModifyWriteStateSpec `protobuf:"bytes,1,opt,name=read_modify_write_spec,json=readModifyWriteSpec,proto3,oneof"`
}

type StateSpec_SetSpec

type StateSpec_SetSpec struct {
	SetSpec *SetStateSpec `protobuf:"bytes,5,opt,name=set_spec,json=setSpec,proto3,oneof"`
}

type TestStreamPayload

type TestStreamPayload struct {

	// (Required) the coder for elements in the TestStream events
	CoderId string `protobuf:"bytes,1,opt,name=coder_id,json=coderId,proto3" json:"coder_id,omitempty"`
	// (Optional) If specified, the TestStream will replay these events.
	Events []*TestStreamPayload_Event `protobuf:"bytes,2,rep,name=events,proto3" json:"events,omitempty"`
	// (Optional) If specified, points to a TestStreamService to be
	// used to retrieve events.
	Endpoint *ApiServiceDescriptor `protobuf:"bytes,3,opt,name=endpoint,proto3" json:"endpoint,omitempty"`
	// contains filtered or unexported fields
}

The payload for the test-only primitive TestStream

func (*TestStreamPayload) Descriptor deprecated

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

Deprecated: Use TestStreamPayload.ProtoReflect.Descriptor instead.

func (*TestStreamPayload) GetCoderId

func (x *TestStreamPayload) GetCoderId() string

func (*TestStreamPayload) GetEndpoint

func (x *TestStreamPayload) GetEndpoint() *ApiServiceDescriptor

func (*TestStreamPayload) GetEvents

func (x *TestStreamPayload) GetEvents() []*TestStreamPayload_Event

func (*TestStreamPayload) ProtoMessage

func (*TestStreamPayload) ProtoMessage()

func (*TestStreamPayload) ProtoReflect

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

func (*TestStreamPayload) Reset

func (x *TestStreamPayload) Reset()

func (*TestStreamPayload) String

func (x *TestStreamPayload) String() string

type TestStreamPayload_Event

type TestStreamPayload_Event struct {

	// Types that are assignable to Event:
	//	*TestStreamPayload_Event_WatermarkEvent
	//	*TestStreamPayload_Event_ProcessingTimeEvent
	//	*TestStreamPayload_Event_ElementEvent
	Event isTestStreamPayload_Event_Event `protobuf_oneof:"event"`
	// contains filtered or unexported fields
}

func (*TestStreamPayload_Event) Descriptor deprecated

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

Deprecated: Use TestStreamPayload_Event.ProtoReflect.Descriptor instead.

func (*TestStreamPayload_Event) GetElementEvent

func (*TestStreamPayload_Event) GetEvent

func (m *TestStreamPayload_Event) GetEvent() isTestStreamPayload_Event_Event

func (*TestStreamPayload_Event) GetProcessingTimeEvent

func (*TestStreamPayload_Event) GetWatermarkEvent

func (*TestStreamPayload_Event) ProtoMessage

func (*TestStreamPayload_Event) ProtoMessage()

func (*TestStreamPayload_Event) ProtoReflect

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

func (*TestStreamPayload_Event) Reset

func (x *TestStreamPayload_Event) Reset()

func (*TestStreamPayload_Event) String

func (x *TestStreamPayload_Event) String() string

type TestStreamPayload_Event_AddElements

type TestStreamPayload_Event_AddElements struct {

	// (Required) The elements to add to the TestStream.
	Elements []*TestStreamPayload_TimestampedElement `protobuf:"bytes,1,rep,name=elements,proto3" json:"elements,omitempty"`
	// (Optional) The output PCollection tag to add these elements to. If
	// unspecified or with an empty string, this will default to the Main
	// PCollection Output.
	Tag string `protobuf:"bytes,3,opt,name=tag,proto3" json:"tag,omitempty"`
	// contains filtered or unexported fields
}

Adds elements to the stream to be emitted.

func (*TestStreamPayload_Event_AddElements) Descriptor deprecated

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

Deprecated: Use TestStreamPayload_Event_AddElements.ProtoReflect.Descriptor instead.

func (*TestStreamPayload_Event_AddElements) GetElements

func (*TestStreamPayload_Event_AddElements) GetTag

func (*TestStreamPayload_Event_AddElements) ProtoMessage

func (*TestStreamPayload_Event_AddElements) ProtoMessage()

func (*TestStreamPayload_Event_AddElements) ProtoReflect

func (*TestStreamPayload_Event_AddElements) Reset

func (*TestStreamPayload_Event_AddElements) String

type TestStreamPayload_Event_AdvanceProcessingTime

type TestStreamPayload_Event_AdvanceProcessingTime struct {

	// (Required) The duration in millisecond to advance by.
	AdvanceDuration int64 `protobuf:"varint,1,opt,name=advance_duration,json=advanceDuration,proto3" json:"advance_duration,omitempty"`
	// contains filtered or unexported fields
}

Advances the processing time clock by the specified amount.

func (*TestStreamPayload_Event_AdvanceProcessingTime) Descriptor deprecated

Deprecated: Use TestStreamPayload_Event_AdvanceProcessingTime.ProtoReflect.Descriptor instead.

func (*TestStreamPayload_Event_AdvanceProcessingTime) GetAdvanceDuration

func (x *TestStreamPayload_Event_AdvanceProcessingTime) GetAdvanceDuration() int64

func (*TestStreamPayload_Event_AdvanceProcessingTime) ProtoMessage

func (*TestStreamPayload_Event_AdvanceProcessingTime) ProtoReflect

func (*TestStreamPayload_Event_AdvanceProcessingTime) Reset

func (*TestStreamPayload_Event_AdvanceProcessingTime) String

type TestStreamPayload_Event_AdvanceWatermark

type TestStreamPayload_Event_AdvanceWatermark struct {

	// (Required) The watermark in millisecond to advance to.
	NewWatermark int64 `protobuf:"varint,1,opt,name=new_watermark,json=newWatermark,proto3" json:"new_watermark,omitempty"`
	// (Optional) The output watermark tag for a PCollection. If unspecified
	// or with an empty string, this will default to the Main PCollection
	// Output
	Tag string `protobuf:"bytes,2,opt,name=tag,proto3" json:"tag,omitempty"`
	// contains filtered or unexported fields
}

Advances the watermark to the specified timestamp.

func (*TestStreamPayload_Event_AdvanceWatermark) Descriptor deprecated

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

Deprecated: Use TestStreamPayload_Event_AdvanceWatermark.ProtoReflect.Descriptor instead.

func (*TestStreamPayload_Event_AdvanceWatermark) GetNewWatermark

func (x *TestStreamPayload_Event_AdvanceWatermark) GetNewWatermark() int64

func (*TestStreamPayload_Event_AdvanceWatermark) GetTag

func (*TestStreamPayload_Event_AdvanceWatermark) ProtoMessage

func (*TestStreamPayload_Event_AdvanceWatermark) ProtoReflect

func (*TestStreamPayload_Event_AdvanceWatermark) Reset

func (*TestStreamPayload_Event_AdvanceWatermark) String

type TestStreamPayload_Event_ElementEvent

type TestStreamPayload_Event_ElementEvent struct {
	ElementEvent *TestStreamPayload_Event_AddElements `protobuf:"bytes,3,opt,name=element_event,json=elementEvent,proto3,oneof"`
}

type TestStreamPayload_Event_ProcessingTimeEvent

type TestStreamPayload_Event_ProcessingTimeEvent struct {
	ProcessingTimeEvent *TestStreamPayload_Event_AdvanceProcessingTime `protobuf:"bytes,2,opt,name=processing_time_event,json=processingTimeEvent,proto3,oneof"`
}

type TestStreamPayload_Event_WatermarkEvent

type TestStreamPayload_Event_WatermarkEvent struct {
	WatermarkEvent *TestStreamPayload_Event_AdvanceWatermark `protobuf:"bytes,1,opt,name=watermark_event,json=watermarkEvent,proto3,oneof"`
}

type TestStreamPayload_TimestampedElement

type TestStreamPayload_TimestampedElement struct {

	// (Required) The element encoded. Currently the TestStream only supports
	// encoding primitives.
	EncodedElement []byte `protobuf:"bytes,1,opt,name=encoded_element,json=encodedElement,proto3" json:"encoded_element,omitempty"`
	// (Required) The event timestamp in millisecond of this element.
	Timestamp int64 `protobuf:"varint,2,opt,name=timestamp,proto3" json:"timestamp,omitempty"`
	// contains filtered or unexported fields
}

A single element inside of the TestStream.

func (*TestStreamPayload_TimestampedElement) Descriptor deprecated

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

Deprecated: Use TestStreamPayload_TimestampedElement.ProtoReflect.Descriptor instead.

func (*TestStreamPayload_TimestampedElement) GetEncodedElement

func (x *TestStreamPayload_TimestampedElement) GetEncodedElement() []byte

func (*TestStreamPayload_TimestampedElement) GetTimestamp

func (x *TestStreamPayload_TimestampedElement) GetTimestamp() int64

func (*TestStreamPayload_TimestampedElement) ProtoMessage

func (*TestStreamPayload_TimestampedElement) ProtoMessage()

func (*TestStreamPayload_TimestampedElement) ProtoReflect

func (*TestStreamPayload_TimestampedElement) Reset

func (*TestStreamPayload_TimestampedElement) String

type TestStreamServiceClient

type TestStreamServiceClient interface {
	// A TestStream will request for events using this RPC.
	Events(ctx context.Context, in *EventsRequest, opts ...grpc.CallOption) (TestStreamService_EventsClient, error)
}

TestStreamServiceClient is the client API for TestStreamService service.

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

type TestStreamServiceServer

type TestStreamServiceServer interface {
	// A TestStream will request for events using this RPC.
	Events(*EventsRequest, TestStreamService_EventsServer) error
}

TestStreamServiceServer is the server API for TestStreamService service.

type TestStreamService_EventsClient

type TestStreamService_EventsClient interface {
	Recv() (*TestStreamPayload_Event, error)
	grpc.ClientStream
}

type TestStreamService_EventsServer

type TestStreamService_EventsServer interface {
	Send(*TestStreamPayload_Event) error
	grpc.ServerStream
}

type TimeDomain

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

The different time domains in the Beam model.

func (*TimeDomain) Descriptor deprecated

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

Deprecated: Use TimeDomain.ProtoReflect.Descriptor instead.

func (*TimeDomain) ProtoMessage

func (*TimeDomain) ProtoMessage()

func (*TimeDomain) ProtoReflect

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

func (*TimeDomain) Reset

func (x *TimeDomain) Reset()

func (*TimeDomain) String

func (x *TimeDomain) String() string

type TimeDomain_Enum

type TimeDomain_Enum int32
const (
	TimeDomain_UNSPECIFIED TimeDomain_Enum = 0
	// Event time is time from the perspective of the data
	TimeDomain_EVENT_TIME TimeDomain_Enum = 1
	// Processing time is time from the perspective of the
	// execution of your pipeline
	TimeDomain_PROCESSING_TIME TimeDomain_Enum = 2
)

func (TimeDomain_Enum) Descriptor

func (TimeDomain_Enum) Enum

func (x TimeDomain_Enum) Enum() *TimeDomain_Enum

func (TimeDomain_Enum) EnumDescriptor deprecated

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

Deprecated: Use TimeDomain_Enum.Descriptor instead.

func (TimeDomain_Enum) Number

func (TimeDomain_Enum) String

func (x TimeDomain_Enum) String() string

func (TimeDomain_Enum) Type

type TimerFamilySpec

type TimerFamilySpec struct {
	TimeDomain         TimeDomain_Enum `` /* 147-byte string literal not displayed */
	TimerFamilyCoderId string          `protobuf:"bytes,2,opt,name=timer_family_coder_id,json=timerFamilyCoderId,proto3" json:"timer_family_coder_id,omitempty"`
	// contains filtered or unexported fields
}

func (*TimerFamilySpec) Descriptor deprecated

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

Deprecated: Use TimerFamilySpec.ProtoReflect.Descriptor instead.

func (*TimerFamilySpec) GetTimeDomain

func (x *TimerFamilySpec) GetTimeDomain() TimeDomain_Enum

func (*TimerFamilySpec) GetTimerFamilyCoderId

func (x *TimerFamilySpec) GetTimerFamilyCoderId() string

func (*TimerFamilySpec) ProtoMessage

func (*TimerFamilySpec) ProtoMessage()

func (*TimerFamilySpec) ProtoReflect

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

func (*TimerFamilySpec) Reset

func (x *TimerFamilySpec) Reset()

func (*TimerFamilySpec) String

func (x *TimerFamilySpec) String() string

type TimestampTransform

type TimestampTransform struct {

	// Types that are assignable to TimestampTransform:
	//	*TimestampTransform_Delay_
	//	*TimestampTransform_AlignTo_
	TimestampTransform isTimestampTransform_TimestampTransform `protobuf_oneof:"timestamp_transform"`
	// contains filtered or unexported fields
}

A specification for a transformation on a timestamp.

Primarily used by AfterProcessingTime triggers to transform the arrival time of input to a target time for firing.

func (*TimestampTransform) Descriptor deprecated

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

Deprecated: Use TimestampTransform.ProtoReflect.Descriptor instead.

func (*TimestampTransform) GetAlignTo

func (*TimestampTransform) GetDelay

func (*TimestampTransform) GetTimestampTransform

func (m *TimestampTransform) GetTimestampTransform() isTimestampTransform_TimestampTransform

func (*TimestampTransform) ProtoMessage

func (*TimestampTransform) ProtoMessage()

func (*TimestampTransform) ProtoReflect

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

func (*TimestampTransform) Reset

func (x *TimestampTransform) Reset()

func (*TimestampTransform) String

func (x *TimestampTransform) String() string

type TimestampTransform_AlignTo

type TimestampTransform_AlignTo struct {

	// (Required) A duration to which delays should be quantized
	// in milliseconds.
	Period int64 `protobuf:"varint,3,opt,name=period,proto3" json:"period,omitempty"`
	// (Required) An offset from 0 for the quantization specified by
	// alignment_size, in milliseconds
	Offset int64 `protobuf:"varint,4,opt,name=offset,proto3" json:"offset,omitempty"`
	// contains filtered or unexported fields
}

func (*TimestampTransform_AlignTo) Descriptor deprecated

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

Deprecated: Use TimestampTransform_AlignTo.ProtoReflect.Descriptor instead.

func (*TimestampTransform_AlignTo) GetOffset

func (x *TimestampTransform_AlignTo) GetOffset() int64

func (*TimestampTransform_AlignTo) GetPeriod

func (x *TimestampTransform_AlignTo) GetPeriod() int64

func (*TimestampTransform_AlignTo) ProtoMessage

func (*TimestampTransform_AlignTo) ProtoMessage()

func (*TimestampTransform_AlignTo) ProtoReflect

func (*TimestampTransform_AlignTo) Reset

func (x *TimestampTransform_AlignTo) Reset()

func (*TimestampTransform_AlignTo) String

func (x *TimestampTransform_AlignTo) String() string

type TimestampTransform_AlignTo_

type TimestampTransform_AlignTo_ struct {
	AlignTo *TimestampTransform_AlignTo `protobuf:"bytes,2,opt,name=align_to,json=alignTo,proto3,oneof"`
}

type TimestampTransform_Delay

type TimestampTransform_Delay struct {

	// (Required) The delay, in milliseconds.
	DelayMillis int64 `protobuf:"varint,1,opt,name=delay_millis,json=delayMillis,proto3" json:"delay_millis,omitempty"`
	// contains filtered or unexported fields
}

func (*TimestampTransform_Delay) Descriptor deprecated

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

Deprecated: Use TimestampTransform_Delay.ProtoReflect.Descriptor instead.

func (*TimestampTransform_Delay) GetDelayMillis

func (x *TimestampTransform_Delay) GetDelayMillis() int64

func (*TimestampTransform_Delay) ProtoMessage

func (*TimestampTransform_Delay) ProtoMessage()

func (*TimestampTransform_Delay) ProtoReflect

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

func (*TimestampTransform_Delay) Reset

func (x *TimestampTransform_Delay) Reset()

func (*TimestampTransform_Delay) String

func (x *TimestampTransform_Delay) String() string

type TimestampTransform_Delay_

type TimestampTransform_Delay_ struct {
	Delay *TimestampTransform_Delay `protobuf:"bytes,1,opt,name=delay,proto3,oneof"`
}

type Trigger

type Trigger struct {

	// The full disjoint union of possible triggers.
	//
	// Types that are assignable to Trigger:
	//	*Trigger_AfterAll_
	//	*Trigger_AfterAny_
	//	*Trigger_AfterEach_
	//	*Trigger_AfterEndOfWindow_
	//	*Trigger_AfterProcessingTime_
	//	*Trigger_AfterSynchronizedProcessingTime_
	//	*Trigger_Always_
	//	*Trigger_Default_
	//	*Trigger_ElementCount_
	//	*Trigger_Never_
	//	*Trigger_OrFinally_
	//	*Trigger_Repeat_
	Trigger isTrigger_Trigger `protobuf_oneof:"trigger"`
	// contains filtered or unexported fields
}

A small DSL for expressing when to emit new aggregations from a GroupByKey or CombinePerKey

A trigger is described in terms of when it is _ready_ to permit output.

func (*Trigger) Descriptor deprecated

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

Deprecated: Use Trigger.ProtoReflect.Descriptor instead.

func (*Trigger) GetAfterAll

func (x *Trigger) GetAfterAll() *Trigger_AfterAll

func (*Trigger) GetAfterAny

func (x *Trigger) GetAfterAny() *Trigger_AfterAny

func (*Trigger) GetAfterEach

func (x *Trigger) GetAfterEach() *Trigger_AfterEach

func (*Trigger) GetAfterEndOfWindow

func (x *Trigger) GetAfterEndOfWindow() *Trigger_AfterEndOfWindow

func (*Trigger) GetAfterProcessingTime

func (x *Trigger) GetAfterProcessingTime() *Trigger_AfterProcessingTime

func (*Trigger) GetAfterSynchronizedProcessingTime

func (x *Trigger) GetAfterSynchronizedProcessingTime() *Trigger_AfterSynchronizedProcessingTime

func (*Trigger) GetAlways

func (x *Trigger) GetAlways() *Trigger_Always

func (*Trigger) GetDefault

func (x *Trigger) GetDefault() *Trigger_Default

func (*Trigger) GetElementCount

func (x *Trigger) GetElementCount() *Trigger_ElementCount

func (*Trigger) GetNever

func (x *Trigger) GetNever() *Trigger_Never

func (*Trigger) GetOrFinally

func (x *Trigger) GetOrFinally() *Trigger_OrFinally

func (*Trigger) GetRepeat

func (x *Trigger) GetRepeat() *Trigger_Repeat

func (*Trigger) GetTrigger

func (m *Trigger) GetTrigger() isTrigger_Trigger

func (*Trigger) ProtoMessage

func (*Trigger) ProtoMessage()

func (*Trigger) ProtoReflect

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

func (*Trigger) Reset

func (x *Trigger) Reset()

func (*Trigger) String

func (x *Trigger) String() string

type Trigger_AfterAll

type Trigger_AfterAll struct {
	Subtriggers []*Trigger `protobuf:"bytes,1,rep,name=subtriggers,proto3" json:"subtriggers,omitempty"`
	// contains filtered or unexported fields
}

Ready when all subtriggers are ready.

func (*Trigger_AfterAll) Descriptor deprecated

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

Deprecated: Use Trigger_AfterAll.ProtoReflect.Descriptor instead.

func (*Trigger_AfterAll) GetSubtriggers

func (x *Trigger_AfterAll) GetSubtriggers() []*Trigger

func (*Trigger_AfterAll) ProtoMessage

func (*Trigger_AfterAll) ProtoMessage()

func (*Trigger_AfterAll) ProtoReflect

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

func (*Trigger_AfterAll) Reset

func (x *Trigger_AfterAll) Reset()

func (*Trigger_AfterAll) String

func (x *Trigger_AfterAll) String() string

type Trigger_AfterAll_

type Trigger_AfterAll_ struct {
	AfterAll *Trigger_AfterAll `protobuf:"bytes,1,opt,name=after_all,json=afterAll,proto3,oneof"`
}

type Trigger_AfterAny

type Trigger_AfterAny struct {
	Subtriggers []*Trigger `protobuf:"bytes,1,rep,name=subtriggers,proto3" json:"subtriggers,omitempty"`
	// contains filtered or unexported fields
}

Ready when any subtrigger is ready.

func (*Trigger_AfterAny) Descriptor deprecated

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

Deprecated: Use Trigger_AfterAny.ProtoReflect.Descriptor instead.

func (*Trigger_AfterAny) GetSubtriggers

func (x *Trigger_AfterAny) GetSubtriggers() []*Trigger

func (*Trigger_AfterAny) ProtoMessage

func (*Trigger_AfterAny) ProtoMessage()

func (*Trigger_AfterAny) ProtoReflect

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

func (*Trigger_AfterAny) Reset

func (x *Trigger_AfterAny) Reset()

func (*Trigger_AfterAny) String

func (x *Trigger_AfterAny) String() string

type Trigger_AfterAny_

type Trigger_AfterAny_ struct {
	AfterAny *Trigger_AfterAny `protobuf:"bytes,2,opt,name=after_any,json=afterAny,proto3,oneof"`
}

type Trigger_AfterEach

type Trigger_AfterEach struct {
	Subtriggers []*Trigger `protobuf:"bytes,1,rep,name=subtriggers,proto3" json:"subtriggers,omitempty"`
	// contains filtered or unexported fields
}

Starting with the first subtrigger, ready when the _current_ subtrigger is ready. After output, advances the current trigger by one.

func (*Trigger_AfterEach) Descriptor deprecated

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

Deprecated: Use Trigger_AfterEach.ProtoReflect.Descriptor instead.

func (*Trigger_AfterEach) GetSubtriggers

func (x *Trigger_AfterEach) GetSubtriggers() []*Trigger

func (*Trigger_AfterEach) ProtoMessage

func (*Trigger_AfterEach) ProtoMessage()

func (*Trigger_AfterEach) ProtoReflect

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

func (*Trigger_AfterEach) Reset

func (x *Trigger_AfterEach) Reset()

func (*Trigger_AfterEach) String

func (x *Trigger_AfterEach) String() string

type Trigger_AfterEach_

type Trigger_AfterEach_ struct {
	AfterEach *Trigger_AfterEach `protobuf:"bytes,3,opt,name=after_each,json=afterEach,proto3,oneof"`
}

type Trigger_AfterEndOfWindow

type Trigger_AfterEndOfWindow struct {

	// (Optional) A trigger governing output prior to the end of the window.
	EarlyFirings *Trigger `protobuf:"bytes,1,opt,name=early_firings,json=earlyFirings,proto3" json:"early_firings,omitempty"`
	// (Optional) A trigger governing output after the end of the window.
	LateFirings *Trigger `protobuf:"bytes,2,opt,name=late_firings,json=lateFirings,proto3" json:"late_firings,omitempty"`
	// contains filtered or unexported fields
}

Ready after the input watermark is past the end of the window.

May have implicitly-repeated subtriggers for early and late firings. When the end of the window is reached, the trigger transitions between the subtriggers.

func (*Trigger_AfterEndOfWindow) Descriptor deprecated

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

Deprecated: Use Trigger_AfterEndOfWindow.ProtoReflect.Descriptor instead.

func (*Trigger_AfterEndOfWindow) GetEarlyFirings

func (x *Trigger_AfterEndOfWindow) GetEarlyFirings() *Trigger

func (*Trigger_AfterEndOfWindow) GetLateFirings

func (x *Trigger_AfterEndOfWindow) GetLateFirings() *Trigger

func (*Trigger_AfterEndOfWindow) ProtoMessage

func (*Trigger_AfterEndOfWindow) ProtoMessage()

func (*Trigger_AfterEndOfWindow) ProtoReflect

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

func (*Trigger_AfterEndOfWindow) Reset

func (x *Trigger_AfterEndOfWindow) Reset()

func (*Trigger_AfterEndOfWindow) String

func (x *Trigger_AfterEndOfWindow) String() string

type Trigger_AfterEndOfWindow_

type Trigger_AfterEndOfWindow_ struct {
	AfterEndOfWindow *Trigger_AfterEndOfWindow `protobuf:"bytes,4,opt,name=after_end_of_window,json=afterEndOfWindow,proto3,oneof"`
}

type Trigger_AfterProcessingTime

type Trigger_AfterProcessingTime struct {

	// (Required) The transforms to apply to an arriving element's timestamp,
	// in order
	TimestampTransforms []*TimestampTransform `protobuf:"bytes,1,rep,name=timestamp_transforms,json=timestampTransforms,proto3" json:"timestamp_transforms,omitempty"`
	// contains filtered or unexported fields
}

After input arrives, ready when the specified delay has passed.

func (*Trigger_AfterProcessingTime) Descriptor deprecated

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

Deprecated: Use Trigger_AfterProcessingTime.ProtoReflect.Descriptor instead.

func (*Trigger_AfterProcessingTime) GetTimestampTransforms

func (x *Trigger_AfterProcessingTime) GetTimestampTransforms() []*TimestampTransform

func (*Trigger_AfterProcessingTime) ProtoMessage

func (*Trigger_AfterProcessingTime) ProtoMessage()

func (*Trigger_AfterProcessingTime) ProtoReflect

func (*Trigger_AfterProcessingTime) Reset

func (x *Trigger_AfterProcessingTime) Reset()

func (*Trigger_AfterProcessingTime) String

func (x *Trigger_AfterProcessingTime) String() string

type Trigger_AfterProcessingTime_

type Trigger_AfterProcessingTime_ struct {
	AfterProcessingTime *Trigger_AfterProcessingTime `protobuf:"bytes,5,opt,name=after_processing_time,json=afterProcessingTime,proto3,oneof"`
}

type Trigger_AfterSynchronizedProcessingTime

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

Ready whenever upstream processing time has all caught up with the arrival time of an input element

func (*Trigger_AfterSynchronizedProcessingTime) Descriptor deprecated

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

Deprecated: Use Trigger_AfterSynchronizedProcessingTime.ProtoReflect.Descriptor instead.

func (*Trigger_AfterSynchronizedProcessingTime) ProtoMessage

func (*Trigger_AfterSynchronizedProcessingTime) ProtoReflect

func (*Trigger_AfterSynchronizedProcessingTime) Reset

func (*Trigger_AfterSynchronizedProcessingTime) String

type Trigger_AfterSynchronizedProcessingTime_

type Trigger_AfterSynchronizedProcessingTime_ struct {
	AfterSynchronizedProcessingTime *Trigger_AfterSynchronizedProcessingTime `protobuf:"bytes,6,opt,name=after_synchronized_processing_time,json=afterSynchronizedProcessingTime,proto3,oneof"`
}

type Trigger_Always

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

Always ready. This can also be expressed as ElementCount(1) but is more explicit.

func (*Trigger_Always) Descriptor deprecated

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

Deprecated: Use Trigger_Always.ProtoReflect.Descriptor instead.

func (*Trigger_Always) ProtoMessage

func (*Trigger_Always) ProtoMessage()

func (*Trigger_Always) ProtoReflect

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

func (*Trigger_Always) Reset

func (x *Trigger_Always) Reset()

func (*Trigger_Always) String

func (x *Trigger_Always) String() string

type Trigger_Always_

type Trigger_Always_ struct {
	Always *Trigger_Always `protobuf:"bytes,12,opt,name=always,proto3,oneof"`
}

type Trigger_Default

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

The default trigger. Equivalent to Repeat { AfterEndOfWindow } but specially denoted to indicate the user did not alter the triggering.

func (*Trigger_Default) Descriptor deprecated

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

Deprecated: Use Trigger_Default.ProtoReflect.Descriptor instead.

func (*Trigger_Default) ProtoMessage

func (*Trigger_Default) ProtoMessage()

func (*Trigger_Default) ProtoReflect

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

func (*Trigger_Default) Reset

func (x *Trigger_Default) Reset()

func (*Trigger_Default) String

func (x *Trigger_Default) String() string

type Trigger_Default_

type Trigger_Default_ struct {
	Default *Trigger_Default `protobuf:"bytes,7,opt,name=default,proto3,oneof"`
}

type Trigger_ElementCount

type Trigger_ElementCount struct {
	ElementCount int32 `protobuf:"varint,1,opt,name=element_count,json=elementCount,proto3" json:"element_count,omitempty"`
	// contains filtered or unexported fields
}

Ready whenever the requisite number of input elements have arrived

func (*Trigger_ElementCount) Descriptor deprecated

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

Deprecated: Use Trigger_ElementCount.ProtoReflect.Descriptor instead.

func (*Trigger_ElementCount) GetElementCount

func (x *Trigger_ElementCount) GetElementCount() int32

func (*Trigger_ElementCount) ProtoMessage

func (*Trigger_ElementCount) ProtoMessage()

func (*Trigger_ElementCount) ProtoReflect

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

func (*Trigger_ElementCount) Reset

func (x *Trigger_ElementCount) Reset()

func (*Trigger_ElementCount) String

func (x *Trigger_ElementCount) String() string

type Trigger_ElementCount_

type Trigger_ElementCount_ struct {
	ElementCount *Trigger_ElementCount `protobuf:"bytes,8,opt,name=element_count,json=elementCount,proto3,oneof"`
}

type Trigger_Never

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

Never ready. There will only be an ON_TIME output and a final output at window expiration.

func (*Trigger_Never) Descriptor deprecated

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

Deprecated: Use Trigger_Never.ProtoReflect.Descriptor instead.

func (*Trigger_Never) ProtoMessage

func (*Trigger_Never) ProtoMessage()

func (*Trigger_Never) ProtoReflect

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

func (*Trigger_Never) Reset

func (x *Trigger_Never) Reset()

func (*Trigger_Never) String

func (x *Trigger_Never) String() string

type Trigger_Never_

type Trigger_Never_ struct {
	Never *Trigger_Never `protobuf:"bytes,9,opt,name=never,proto3,oneof"`
}

type Trigger_OrFinally

type Trigger_OrFinally struct {

	// (Required) Trigger governing main output; may fire repeatedly.
	Main *Trigger `protobuf:"bytes,1,opt,name=main,proto3" json:"main,omitempty"`
	// (Required) Trigger governing termination of output.
	Finally *Trigger `protobuf:"bytes,2,opt,name=finally,proto3" json:"finally,omitempty"`
	// contains filtered or unexported fields
}

Ready whenever either of its subtriggers are ready, but finishes output when the finally subtrigger fires.

func (*Trigger_OrFinally) Descriptor deprecated

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

Deprecated: Use Trigger_OrFinally.ProtoReflect.Descriptor instead.

func (*Trigger_OrFinally) GetFinally

func (x *Trigger_OrFinally) GetFinally() *Trigger

func (*Trigger_OrFinally) GetMain

func (x *Trigger_OrFinally) GetMain() *Trigger

func (*Trigger_OrFinally) ProtoMessage

func (*Trigger_OrFinally) ProtoMessage()

func (*Trigger_OrFinally) ProtoReflect

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

func (*Trigger_OrFinally) Reset

func (x *Trigger_OrFinally) Reset()

func (*Trigger_OrFinally) String

func (x *Trigger_OrFinally) String() string

type Trigger_OrFinally_

type Trigger_OrFinally_ struct {
	OrFinally *Trigger_OrFinally `protobuf:"bytes,10,opt,name=or_finally,json=orFinally,proto3,oneof"`
}

type Trigger_Repeat

type Trigger_Repeat struct {

	// (Require) Trigger that is run repeatedly.
	Subtrigger *Trigger `protobuf:"bytes,1,opt,name=subtrigger,proto3" json:"subtrigger,omitempty"`
	// contains filtered or unexported fields
}

Ready whenever the subtrigger is ready; resets state when the subtrigger completes.

func (*Trigger_Repeat) Descriptor deprecated

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

Deprecated: Use Trigger_Repeat.ProtoReflect.Descriptor instead.

func (*Trigger_Repeat) GetSubtrigger

func (x *Trigger_Repeat) GetSubtrigger() *Trigger

func (*Trigger_Repeat) ProtoMessage

func (*Trigger_Repeat) ProtoMessage()

func (*Trigger_Repeat) ProtoReflect

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

func (*Trigger_Repeat) Reset

func (x *Trigger_Repeat) Reset()

func (*Trigger_Repeat) String

func (x *Trigger_Repeat) String() string

type Trigger_Repeat_

type Trigger_Repeat_ struct {
	Repeat *Trigger_Repeat `protobuf:"bytes,11,opt,name=repeat,proto3,oneof"`
}

type UnimplementedTestStreamServiceServer

type UnimplementedTestStreamServiceServer struct {
}

UnimplementedTestStreamServiceServer can be embedded to have forward compatible implementations.

func (*UnimplementedTestStreamServiceServer) Events

type WindowIntoPayload

type WindowIntoPayload struct {

	// (Required) The FunctionSpec of the WindowFn.
	WindowFn *FunctionSpec `protobuf:"bytes,1,opt,name=window_fn,json=windowFn,proto3" json:"window_fn,omitempty"`
	// contains filtered or unexported fields
}

The payload for the WindowInto transform.

func (*WindowIntoPayload) Descriptor deprecated

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

Deprecated: Use WindowIntoPayload.ProtoReflect.Descriptor instead.

func (*WindowIntoPayload) GetWindowFn

func (x *WindowIntoPayload) GetWindowFn() *FunctionSpec

func (*WindowIntoPayload) ProtoMessage

func (*WindowIntoPayload) ProtoMessage()

func (*WindowIntoPayload) ProtoReflect

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

func (*WindowIntoPayload) Reset

func (x *WindowIntoPayload) Reset()

func (*WindowIntoPayload) String

func (x *WindowIntoPayload) String() string

type WindowingStrategy

type WindowingStrategy struct {

	// (Required) The FunctionSpec of the UDF that assigns windows,
	// merges windows, and shifts timestamps before they are
	// combined according to the OutputTime.
	WindowFn *FunctionSpec `protobuf:"bytes,1,opt,name=window_fn,json=windowFn,proto3" json:"window_fn,omitempty"`
	// (Required) Whether or not the window fn is merging.
	//
	// This knowledge is required for many optimizations.
	MergeStatus MergeStatus_Enum `` /* 151-byte string literal not displayed */
	// (Required) The coder for the windows of this PCollection.
	WindowCoderId string `protobuf:"bytes,3,opt,name=window_coder_id,json=windowCoderId,proto3" json:"window_coder_id,omitempty"`
	// (Required) The trigger to use when grouping this PCollection.
	Trigger *Trigger `protobuf:"bytes,4,opt,name=trigger,proto3" json:"trigger,omitempty"`
	// (Required) The accumulation mode indicates whether new panes are a full
	// replacement for prior panes or whether they are deltas to be combined
	// with other panes (the combine should correspond to whatever the upstream
	// grouping transform is).
	AccumulationMode AccumulationMode_Enum `` /* 171-byte string literal not displayed */
	// (Required) The OutputTime specifies, for a grouping transform, how to
	// compute the aggregate timestamp. The window_fn will first possibly shift
	// it later, then the OutputTime takes the max, min, or ignores it and takes
	// the end of window.
	//
	// This is actually only for input to grouping transforms, but since they
	// may be introduced in runner-specific ways, it is carried along with the
	// windowing strategy.
	OutputTime OutputTime_Enum `` /* 147-byte string literal not displayed */
	// (Required) Indicate when output should be omitted upon window expiration.
	ClosingBehavior ClosingBehavior_Enum `` /* 167-byte string literal not displayed */
	// (Required) The duration, in milliseconds, beyond the end of a window at
	// which the window becomes droppable.
	AllowedLateness int64 `protobuf:"varint,8,opt,name=allowed_lateness,json=allowedLateness,proto3" json:"allowed_lateness,omitempty"`
	// (Required) Indicate whether empty on-time panes should be omitted.
	OnTimeBehavior OnTimeBehavior_Enum `` /* 141-byte string literal not displayed */
	// (Required) Whether or not the window fn assigns inputs to exactly one window
	//
	// This knowledge is required for some optimizations
	AssignsToOneWindow bool `protobuf:"varint,10,opt,name=assigns_to_one_window,json=assignsToOneWindow,proto3" json:"assigns_to_one_window,omitempty"`
	// (Optional) Environment where the current window_fn should be applied in.
	// Runner that executes the pipeline may choose to override this if needed.
	// If not specified, environment will be decided by the runner.
	EnvironmentId string `protobuf:"bytes,11,opt,name=environment_id,json=environmentId,proto3" json:"environment_id,omitempty"`
	// contains filtered or unexported fields
}

A windowing strategy describes the window function, triggering, allowed lateness, and accumulation mode for a PCollection.

TODO: consider inlining field on PCollection

func (*WindowingStrategy) Descriptor deprecated

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

Deprecated: Use WindowingStrategy.ProtoReflect.Descriptor instead.

func (*WindowingStrategy) GetAccumulationMode

func (x *WindowingStrategy) GetAccumulationMode() AccumulationMode_Enum

func (*WindowingStrategy) GetAllowedLateness

func (x *WindowingStrategy) GetAllowedLateness() int64

func (*WindowingStrategy) GetAssignsToOneWindow

func (x *WindowingStrategy) GetAssignsToOneWindow() bool

func (*WindowingStrategy) GetClosingBehavior

func (x *WindowingStrategy) GetClosingBehavior() ClosingBehavior_Enum

func (*WindowingStrategy) GetEnvironmentId

func (x *WindowingStrategy) GetEnvironmentId() string

func (*WindowingStrategy) GetMergeStatus

func (x *WindowingStrategy) GetMergeStatus() MergeStatus_Enum

func (*WindowingStrategy) GetOnTimeBehavior

func (x *WindowingStrategy) GetOnTimeBehavior() OnTimeBehavior_Enum

func (*WindowingStrategy) GetOutputTime

func (x *WindowingStrategy) GetOutputTime() OutputTime_Enum

func (*WindowingStrategy) GetTrigger

func (x *WindowingStrategy) GetTrigger() *Trigger

func (*WindowingStrategy) GetWindowCoderId

func (x *WindowingStrategy) GetWindowCoderId() string

func (*WindowingStrategy) GetWindowFn

func (x *WindowingStrategy) GetWindowFn() *FunctionSpec

func (*WindowingStrategy) ProtoMessage

func (*WindowingStrategy) ProtoMessage()

func (*WindowingStrategy) ProtoReflect

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

func (*WindowingStrategy) Reset

func (x *WindowingStrategy) Reset()

func (*WindowingStrategy) String

func (x *WindowingStrategy) String() string

type WriteFilesPayload

type WriteFilesPayload struct {

	// (Required) The FunctionSpec of the FileBasedSink.
	Sink *FunctionSpec `protobuf:"bytes,1,opt,name=sink,proto3" json:"sink,omitempty"`
	// (Required) The format function.
	FormatFunction           *FunctionSpec         `protobuf:"bytes,2,opt,name=format_function,json=formatFunction,proto3" json:"format_function,omitempty"`
	WindowedWrites           bool                  `protobuf:"varint,3,opt,name=windowed_writes,json=windowedWrites,proto3" json:"windowed_writes,omitempty"`
	RunnerDeterminedSharding bool                  `` /* 136-byte string literal not displayed */
	SideInputs               map[string]*SideInput `` /* 179-byte string literal not displayed */
	// contains filtered or unexported fields
}

The payload for the special-but-not-primitive WriteFiles transform.

func (*WriteFilesPayload) Descriptor deprecated

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

Deprecated: Use WriteFilesPayload.ProtoReflect.Descriptor instead.

func (*WriteFilesPayload) GetFormatFunction

func (x *WriteFilesPayload) GetFormatFunction() *FunctionSpec

func (*WriteFilesPayload) GetRunnerDeterminedSharding

func (x *WriteFilesPayload) GetRunnerDeterminedSharding() bool

func (*WriteFilesPayload) GetSideInputs

func (x *WriteFilesPayload) GetSideInputs() map[string]*SideInput

func (*WriteFilesPayload) GetSink

func (x *WriteFilesPayload) GetSink() *FunctionSpec

func (*WriteFilesPayload) GetWindowedWrites

func (x *WriteFilesPayload) GetWindowedWrites() bool

func (*WriteFilesPayload) ProtoMessage

func (*WriteFilesPayload) ProtoMessage()

func (*WriteFilesPayload) ProtoReflect

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

func (*WriteFilesPayload) Reset

func (x *WriteFilesPayload) Reset()

func (*WriteFilesPayload) String

func (x *WriteFilesPayload) String() string

Jump to

Keyboard shortcuts

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