pipeline_v1

package
v2.3.0-RC1+incompatible Latest Latest
Warning

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

Go to latest
Published: Jan 29, 2018 License: Apache-2.0 Imports: 6 Imported by: 0

Documentation

Overview

Package pipeline_v1 is a generated protocol buffer package.

It is generated from these files:

beam_runner_api.proto
endpoints.proto
standard_window_fns.proto

It has these top-level messages:

Components
MessageWithComponents
Pipeline
PTransform
PCollection
ParDoPayload
Parameter
StateSpec
ValueStateSpec
BagStateSpec
CombiningStateSpec
MapStateSpec
SetStateSpec
TimerSpec
IsBounded
ReadPayload
WindowIntoPayload
CombinePayload
TestStreamPayload
WriteFilesPayload
Coder
WindowingStrategy
MergeStatus
AccumulationMode
ClosingBehavior
OnTimeBehavior
OutputTime
TimeDomain
Trigger
TimestampTransform
SideInput
Environment
SdkFunctionSpec
FunctionSpec
DisplayData
ApiServiceDescriptor
OAuth2ClientCredentialsGrant
FixedWindowsPayload
SlidingWindowsPayload
SessionsPayload

Index

Constants

This section is empty.

Variables

View Source
var AccumulationMode_Enum_name = map[int32]string{
	0: "UNSPECIFIED",
	1: "DISCARDING",
	2: "ACCUMULATING",
}
View Source
var AccumulationMode_Enum_value = map[string]int32{
	"UNSPECIFIED":  0,
	"DISCARDING":   1,
	"ACCUMULATING": 2,
}
View Source
var ClosingBehavior_Enum_name = map[int32]string{
	0: "UNSPECIFIED",
	1: "EMIT_ALWAYS",
	2: "EMIT_IF_NONEMPTY",
}
View Source
var ClosingBehavior_Enum_value = map[string]int32{
	"UNSPECIFIED":      0,
	"EMIT_ALWAYS":      1,
	"EMIT_IF_NONEMPTY": 2,
}
View Source
var DisplayData_Type_Enum_name = map[int32]string{
	0: "UNSPECIFIED",
	1: "STRING",
	2: "INTEGER",
	3: "FLOAT",
	4: "BOOLEAN",
	5: "TIMESTAMP",
	6: "DURATION",
	7: "JAVA_CLASS",
}
View Source
var DisplayData_Type_Enum_value = map[string]int32{
	"UNSPECIFIED": 0,
	"STRING":      1,
	"INTEGER":     2,
	"FLOAT":       3,
	"BOOLEAN":     4,
	"TIMESTAMP":   5,
	"DURATION":    6,
	"JAVA_CLASS":  7,
}
View Source
var IsBounded_Enum_name = map[int32]string{
	0: "UNSPECIFIED",
	1: "UNBOUNDED",
	2: "BOUNDED",
}
View Source
var IsBounded_Enum_value = map[string]int32{
	"UNSPECIFIED": 0,
	"UNBOUNDED":   1,
	"BOUNDED":     2,
}
View Source
var MergeStatus_Enum_name = map[int32]string{
	0: "UNSPECIFIED",
	1: "NON_MERGING",
	2: "NEEDS_MERGE",
	3: "ALREADY_MERGED",
}
View Source
var MergeStatus_Enum_value = map[string]int32{
	"UNSPECIFIED":    0,
	"NON_MERGING":    1,
	"NEEDS_MERGE":    2,
	"ALREADY_MERGED": 3,
}
View Source
var OnTimeBehavior_Enum_name = map[int32]string{
	0: "UNSPECIFIED",
	1: "FIRE_ALWAYS",
	2: "FIRE_IF_NONEMPTY",
}
View Source
var OnTimeBehavior_Enum_value = map[string]int32{
	"UNSPECIFIED":      0,
	"FIRE_ALWAYS":      1,
	"FIRE_IF_NONEMPTY": 2,
}
View Source
var OutputTime_Enum_name = map[int32]string{
	0: "UNSPECIFIED",
	1: "END_OF_WINDOW",
	2: "LATEST_IN_PANE",
	3: "EARLIEST_IN_PANE",
}
View Source
var OutputTime_Enum_value = map[string]int32{
	"UNSPECIFIED":      0,
	"END_OF_WINDOW":    1,
	"LATEST_IN_PANE":   2,
	"EARLIEST_IN_PANE": 3,
}
View Source
var Parameter_Type_Enum_name = map[int32]string{
	0: "UNSPECIFIED",
	1: "WINDOW",
	2: "PIPELINE_OPTIONS",
	3: "RESTRICTION_TRACKER",
}
View Source
var Parameter_Type_Enum_value = map[string]int32{
	"UNSPECIFIED":         0,
	"WINDOW":              1,
	"PIPELINE_OPTIONS":    2,
	"RESTRICTION_TRACKER": 3,
}
View Source
var TimeDomain_Enum_name = map[int32]string{
	0: "UNSPECIFIED",
	1: "EVENT_TIME",
	2: "PROCESSING_TIME",
	3: "SYNCHRONIZED_PROCESSING_TIME",
}
View Source
var TimeDomain_Enum_value = map[string]int32{
	"UNSPECIFIED":                  0,
	"EVENT_TIME":                   1,
	"PROCESSING_TIME":              2,
	"SYNCHRONIZED_PROCESSING_TIME": 3,
}

Functions

This section is empty.

Types

type AccumulationMode

type AccumulationMode struct {
}

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

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

func (*AccumulationMode) ProtoMessage

func (*AccumulationMode) ProtoMessage()

func (*AccumulationMode) Reset

func (m *AccumulationMode) Reset()

func (*AccumulationMode) String

func (m *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
)

func (AccumulationMode_Enum) EnumDescriptor

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

func (AccumulationMode_Enum) String

func (x AccumulationMode_Enum) String() string

type ApiServiceDescriptor

type ApiServiceDescriptor struct {
	// (Required) The URL to connect to.
	Url string `protobuf:"bytes,2,opt,name=url" 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).
	//
	// Types that are valid to be assigned to Authentication:
	//	*ApiServiceDescriptor_Oauth2ClientCredentialsGrant
	Authentication isApiServiceDescriptor_Authentication `protobuf_oneof:"authentication"`
}

func (*ApiServiceDescriptor) Descriptor

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

func (*ApiServiceDescriptor) GetAuthentication

func (m *ApiServiceDescriptor) GetAuthentication() isApiServiceDescriptor_Authentication

func (*ApiServiceDescriptor) GetOauth2ClientCredentialsGrant

func (m *ApiServiceDescriptor) GetOauth2ClientCredentialsGrant() *OAuth2ClientCredentialsGrant

func (*ApiServiceDescriptor) GetUrl

func (m *ApiServiceDescriptor) GetUrl() string

func (*ApiServiceDescriptor) ProtoMessage

func (*ApiServiceDescriptor) ProtoMessage()

func (*ApiServiceDescriptor) Reset

func (m *ApiServiceDescriptor) Reset()

func (*ApiServiceDescriptor) String

func (m *ApiServiceDescriptor) String() string

func (*ApiServiceDescriptor) XXX_OneofFuncs

func (*ApiServiceDescriptor) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, func(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error), func(msg proto.Message) (n int), []interface{})

XXX_OneofFuncs is for the internal use of the proto package.

type ApiServiceDescriptor_Oauth2ClientCredentialsGrant

type ApiServiceDescriptor_Oauth2ClientCredentialsGrant struct {
	Oauth2ClientCredentialsGrant *OAuth2ClientCredentialsGrant `protobuf:"bytes,3,opt,name=oauth2_client_credentials_grant,json=oauth2ClientCredentialsGrant,oneof"`
}

type BagStateSpec

type BagStateSpec struct {
	ElementCoderId string `protobuf:"bytes,1,opt,name=element_coder_id,json=elementCoderId" json:"element_coder_id,omitempty"`
}

func (*BagStateSpec) Descriptor

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

func (*BagStateSpec) GetElementCoderId

func (m *BagStateSpec) GetElementCoderId() string

func (*BagStateSpec) ProtoMessage

func (*BagStateSpec) ProtoMessage()

func (*BagStateSpec) Reset

func (m *BagStateSpec) Reset()

func (*BagStateSpec) String

func (m *BagStateSpec) String() string

type ClosingBehavior

type ClosingBehavior struct {
}

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

func (*ClosingBehavior) Descriptor

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

func (*ClosingBehavior) ProtoMessage

func (*ClosingBehavior) ProtoMessage()

func (*ClosingBehavior) Reset

func (m *ClosingBehavior) Reset()

func (*ClosingBehavior) String

func (m *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) EnumDescriptor

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

func (ClosingBehavior_Enum) String

func (x ClosingBehavior_Enum) String() string

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 agree-upon.
	Spec *SdkFunctionSpec `protobuf:"bytes,1,opt,name=spec" 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 SdkFunctionSpec and all components must be identical, recursively.
	ComponentCoderIds []string `protobuf:"bytes,2,rep,name=component_coder_ids,json=componentCoderIds" json:"component_coder_ids,omitempty"`
}

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

func (*Coder) Descriptor

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

func (*Coder) GetComponentCoderIds

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

func (*Coder) GetSpec

func (m *Coder) GetSpec() *SdkFunctionSpec

func (*Coder) ProtoMessage

func (*Coder) ProtoMessage()

func (*Coder) Reset

func (m *Coder) Reset()

func (*Coder) String

func (m *Coder) String() string

type CombinePayload

type CombinePayload struct {
	// (Required) The SdkFunctionSpec of the CombineFn.
	CombineFn *SdkFunctionSpec `protobuf:"bytes,1,opt,name=combine_fn,json=combineFn" 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" json:"accumulator_coder_id,omitempty"`
	// (Required) Additional pieces of context the DoFn may require that
	// are not otherwise represented in the payload.
	// (may force runners to execute the ParDo differently)
	Parameters []*Parameter `protobuf:"bytes,3,rep,name=parameters" json:"parameters,omitempty"`
	// (Optional) A mapping of local input names to side inputs, describing
	// the expected access pattern.
	SideInputs map[string]*SideInput `` /* 158-byte string literal not displayed */
}

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

func (*CombinePayload) Descriptor

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

func (*CombinePayload) GetAccumulatorCoderId

func (m *CombinePayload) GetAccumulatorCoderId() string

func (*CombinePayload) GetCombineFn

func (m *CombinePayload) GetCombineFn() *SdkFunctionSpec

func (*CombinePayload) GetParameters

func (m *CombinePayload) GetParameters() []*Parameter

func (*CombinePayload) GetSideInputs

func (m *CombinePayload) GetSideInputs() map[string]*SideInput

func (*CombinePayload) ProtoMessage

func (*CombinePayload) ProtoMessage()

func (*CombinePayload) Reset

func (m *CombinePayload) Reset()

func (*CombinePayload) String

func (m *CombinePayload) String() string

type CombiningStateSpec

type CombiningStateSpec struct {
	AccumulatorCoderId string           `protobuf:"bytes,1,opt,name=accumulator_coder_id,json=accumulatorCoderId" json:"accumulator_coder_id,omitempty"`
	CombineFn          *SdkFunctionSpec `protobuf:"bytes,2,opt,name=combine_fn,json=combineFn" json:"combine_fn,omitempty"`
}

func (*CombiningStateSpec) Descriptor

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

func (*CombiningStateSpec) GetAccumulatorCoderId

func (m *CombiningStateSpec) GetAccumulatorCoderId() string

func (*CombiningStateSpec) GetCombineFn

func (m *CombiningStateSpec) GetCombineFn() *SdkFunctionSpec

func (*CombiningStateSpec) ProtoMessage

func (*CombiningStateSpec) ProtoMessage()

func (*CombiningStateSpec) Reset

func (m *CombiningStateSpec) Reset()

func (*CombiningStateSpec) String

func (m *CombiningStateSpec) String() string

type Components

type Components struct {
	// (Required) A map from pipeline-scoped id to PTransform.
	Transforms map[string]*PTransform `` /* 140-byte string literal not displayed */
	// (Required) A map from pipeline-scoped id to PCollection.
	Pcollections map[string]*PCollection `` /* 144-byte string literal not displayed */
	// (Required) A map from pipeline-scoped id to WindowingStrategy.
	WindowingStrategies map[string]*WindowingStrategy `` /* 185-byte string literal not displayed */
	// (Required) A map from pipeline-scoped id to Coder.
	Coders map[string]*Coder `` /* 132-byte string literal not displayed */
	// (Required) A map from pipeline-scoped id to Environment.
	Environments map[string]*Environment `` /* 144-byte string literal not displayed */
}

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

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

func (*Components) GetCoders

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

func (*Components) GetEnvironments

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

func (*Components) GetPcollections

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

func (*Components) GetTransforms

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

func (*Components) GetWindowingStrategies

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

func (*Components) ProtoMessage

func (*Components) ProtoMessage()

func (*Components) Reset

func (m *Components) Reset()

func (*Components) String

func (m *Components) String() string

type DisplayData

type DisplayData struct {
	// (Required) The list of display data.
	Items []*DisplayData_Item `protobuf:"bytes,1,rep,name=items" json:"items,omitempty"`
}

TODO: transfer javadoc here

func (*DisplayData) Descriptor

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

func (*DisplayData) GetItems

func (m *DisplayData) GetItems() []*DisplayData_Item

func (*DisplayData) ProtoMessage

func (*DisplayData) ProtoMessage()

func (*DisplayData) Reset

func (m *DisplayData) Reset()

func (*DisplayData) String

func (m *DisplayData) String() string

type DisplayData_Identifier

type DisplayData_Identifier struct {
	// (Required) The transform originating this display data.
	TransformId string `protobuf:"bytes,1,opt,name=transform_id,json=transformId" json:"transform_id,omitempty"`
	// (Optional) The URN indicating the type of the originating transform,
	// if there is one.
	TransformUrn string `protobuf:"bytes,2,opt,name=transform_urn,json=transformUrn" json:"transform_urn,omitempty"`
	Key          string `protobuf:"bytes,3,opt,name=key" json:"key,omitempty"`
}

A complete identifier for a DisplayData.Item

func (*DisplayData_Identifier) Descriptor

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

func (*DisplayData_Identifier) GetKey

func (m *DisplayData_Identifier) GetKey() string

func (*DisplayData_Identifier) GetTransformId

func (m *DisplayData_Identifier) GetTransformId() string

func (*DisplayData_Identifier) GetTransformUrn

func (m *DisplayData_Identifier) GetTransformUrn() string

func (*DisplayData_Identifier) ProtoMessage

func (*DisplayData_Identifier) ProtoMessage()

func (*DisplayData_Identifier) Reset

func (m *DisplayData_Identifier) Reset()

func (*DisplayData_Identifier) String

func (m *DisplayData_Identifier) String() string

type DisplayData_Item

type DisplayData_Item struct {
	// (Required)
	Id *DisplayData_Identifier `protobuf:"bytes,1,opt,name=id" json:"id,omitempty"`
	// (Required)
	Type DisplayData_Type_Enum `protobuf:"varint,2,opt,name=type,enum=org.apache.beam.model.pipeline.v1.DisplayData_Type_Enum" json:"type,omitempty"`
	// (Required)
	Value *google_protobuf.Any `protobuf:"bytes,3,opt,name=value" json:"value,omitempty"`
	// (Optional)
	ShortValue *google_protobuf.Any `protobuf:"bytes,4,opt,name=short_value,json=shortValue" json:"short_value,omitempty"`
	// (Optional)
	Label string `protobuf:"bytes,5,opt,name=label" json:"label,omitempty"`
	// (Optional)
	LinkUrl string `protobuf:"bytes,6,opt,name=link_url,json=linkUrl" json:"link_url,omitempty"`
}

A single item of display data.

func (*DisplayData_Item) Descriptor

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

func (*DisplayData_Item) GetId

func (*DisplayData_Item) GetLabel

func (m *DisplayData_Item) GetLabel() string

func (*DisplayData_Item) GetLinkUrl

func (m *DisplayData_Item) GetLinkUrl() string

func (*DisplayData_Item) GetShortValue

func (m *DisplayData_Item) GetShortValue() *google_protobuf.Any

func (*DisplayData_Item) GetType

func (*DisplayData_Item) GetValue

func (m *DisplayData_Item) GetValue() *google_protobuf.Any

func (*DisplayData_Item) ProtoMessage

func (*DisplayData_Item) ProtoMessage()

func (*DisplayData_Item) Reset

func (m *DisplayData_Item) Reset()

func (*DisplayData_Item) String

func (m *DisplayData_Item) String() string

type DisplayData_Type

type DisplayData_Type struct {
}

func (*DisplayData_Type) Descriptor

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

func (*DisplayData_Type) ProtoMessage

func (*DisplayData_Type) ProtoMessage()

func (*DisplayData_Type) Reset

func (m *DisplayData_Type) Reset()

func (*DisplayData_Type) String

func (m *DisplayData_Type) String() string

type DisplayData_Type_Enum

type DisplayData_Type_Enum int32
const (
	DisplayData_Type_UNSPECIFIED DisplayData_Type_Enum = 0
	DisplayData_Type_STRING      DisplayData_Type_Enum = 1
	DisplayData_Type_INTEGER     DisplayData_Type_Enum = 2
	DisplayData_Type_FLOAT       DisplayData_Type_Enum = 3
	DisplayData_Type_BOOLEAN     DisplayData_Type_Enum = 4
	DisplayData_Type_TIMESTAMP   DisplayData_Type_Enum = 5
	DisplayData_Type_DURATION    DisplayData_Type_Enum = 6
	DisplayData_Type_JAVA_CLASS  DisplayData_Type_Enum = 7
)

func (DisplayData_Type_Enum) EnumDescriptor

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

func (DisplayData_Type_Enum) String

func (x DisplayData_Type_Enum) String() string

type Environment

type Environment struct {
	// (Required) The URL of a container
	//
	// TODO: reconcile with Fn API's DockerContainer structure by
	// adding adequate metadata to know how to interpret the container
	Url string `protobuf:"bytes,1,opt,name=url" json:"url,omitempty"`
}

An environment for executing UDFs. Generally an SDK container URL, but there can be many for a single SDK, for example to provide dependency isolation.

func (*Environment) Descriptor

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

func (*Environment) GetUrl

func (m *Environment) GetUrl() string

func (*Environment) ProtoMessage

func (*Environment) ProtoMessage()

func (*Environment) Reset

func (m *Environment) Reset()

func (*Environment) String

func (m *Environment) String() string

type FixedWindowsPayload

type FixedWindowsPayload struct {
	Size   *google_protobuf1.Duration  `protobuf:"bytes,1,opt,name=size" json:"size,omitempty"`
	Offset *google_protobuf2.Timestamp `protobuf:"bytes,2,opt,name=offset" json:"offset,omitempty"`
}

beam:windowfn:fixed_windows:v0.1

func (*FixedWindowsPayload) Descriptor

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

func (*FixedWindowsPayload) GetOffset

func (*FixedWindowsPayload) GetSize

func (*FixedWindowsPayload) ProtoMessage

func (*FixedWindowsPayload) ProtoMessage()

func (*FixedWindowsPayload) Reset

func (m *FixedWindowsPayload) Reset()

func (*FixedWindowsPayload) String

func (m *FixedWindowsPayload) String() string

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" 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"`
}

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 "urn:beam:transform:Top" or "urn:beam:windowfn: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 "urn: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

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

func (*FunctionSpec) GetPayload

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

func (*FunctionSpec) GetUrn

func (m *FunctionSpec) GetUrn() string

func (*FunctionSpec) ProtoMessage

func (*FunctionSpec) ProtoMessage()

func (*FunctionSpec) Reset

func (m *FunctionSpec) Reset()

func (*FunctionSpec) String

func (m *FunctionSpec) String() string

type IsBounded

type IsBounded struct {
}

func (*IsBounded) Descriptor

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

func (*IsBounded) ProtoMessage

func (*IsBounded) ProtoMessage()

func (*IsBounded) Reset

func (m *IsBounded) Reset()

func (*IsBounded) String

func (m *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) EnumDescriptor

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

func (IsBounded_Enum) String

func (x IsBounded_Enum) String() string

type MapStateSpec

type MapStateSpec struct {
	KeyCoderId   string `protobuf:"bytes,1,opt,name=key_coder_id,json=keyCoderId" json:"key_coder_id,omitempty"`
	ValueCoderId string `protobuf:"bytes,2,opt,name=value_coder_id,json=valueCoderId" json:"value_coder_id,omitempty"`
}

func (*MapStateSpec) Descriptor

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

func (*MapStateSpec) GetKeyCoderId

func (m *MapStateSpec) GetKeyCoderId() string

func (*MapStateSpec) GetValueCoderId

func (m *MapStateSpec) GetValueCoderId() string

func (*MapStateSpec) ProtoMessage

func (*MapStateSpec) ProtoMessage()

func (*MapStateSpec) Reset

func (m *MapStateSpec) Reset()

func (*MapStateSpec) String

func (m *MapStateSpec) String() string

type MergeStatus

type MergeStatus struct {
}

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

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

func (*MergeStatus) ProtoMessage

func (*MergeStatus) ProtoMessage()

func (*MergeStatus) Reset

func (m *MergeStatus) Reset()

func (*MergeStatus) String

func (m *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) EnumDescriptor

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

func (MergeStatus_Enum) String

func (x MergeStatus_Enum) String() string

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" json:"components,omitempty"`
	// (Required) The root message that may contain pointers
	// that should be resolved by looking inside components.
	//
	// Types that are valid to be assigned to Root:
	//	*MessageWithComponents_Coder
	//	*MessageWithComponents_CombinePayload
	//	*MessageWithComponents_SdkFunctionSpec
	//	*MessageWithComponents_ParDoPayload
	//	*MessageWithComponents_Ptransform
	//	*MessageWithComponents_Pcollection
	//	*MessageWithComponents_ReadPayload
	//	*MessageWithComponents_SideInput
	//	*MessageWithComponents_WindowIntoPayload
	//	*MessageWithComponents_WindowingStrategy
	//	*MessageWithComponents_FunctionSpec
	Root isMessageWithComponents_Root `protobuf_oneof:"root"`
}

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

func (*MessageWithComponents) Descriptor

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

func (*MessageWithComponents) GetCoder

func (m *MessageWithComponents) GetCoder() *Coder

func (*MessageWithComponents) GetCombinePayload

func (m *MessageWithComponents) GetCombinePayload() *CombinePayload

func (*MessageWithComponents) GetComponents

func (m *MessageWithComponents) GetComponents() *Components

func (*MessageWithComponents) GetFunctionSpec

func (m *MessageWithComponents) GetFunctionSpec() *FunctionSpec

func (*MessageWithComponents) GetParDoPayload

func (m *MessageWithComponents) GetParDoPayload() *ParDoPayload

func (*MessageWithComponents) GetPcollection

func (m *MessageWithComponents) GetPcollection() *PCollection

func (*MessageWithComponents) GetPtransform

func (m *MessageWithComponents) GetPtransform() *PTransform

func (*MessageWithComponents) GetReadPayload

func (m *MessageWithComponents) GetReadPayload() *ReadPayload

func (*MessageWithComponents) GetRoot

func (m *MessageWithComponents) GetRoot() isMessageWithComponents_Root

func (*MessageWithComponents) GetSdkFunctionSpec

func (m *MessageWithComponents) GetSdkFunctionSpec() *SdkFunctionSpec

func (*MessageWithComponents) GetSideInput

func (m *MessageWithComponents) GetSideInput() *SideInput

func (*MessageWithComponents) GetWindowIntoPayload

func (m *MessageWithComponents) GetWindowIntoPayload() *WindowIntoPayload

func (*MessageWithComponents) GetWindowingStrategy

func (m *MessageWithComponents) GetWindowingStrategy() *WindowingStrategy

func (*MessageWithComponents) ProtoMessage

func (*MessageWithComponents) ProtoMessage()

func (*MessageWithComponents) Reset

func (m *MessageWithComponents) Reset()

func (*MessageWithComponents) String

func (m *MessageWithComponents) String() string

func (*MessageWithComponents) XXX_OneofFuncs

func (*MessageWithComponents) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, func(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error), func(msg proto.Message) (n int), []interface{})

XXX_OneofFuncs is for the internal use of the proto package.

type MessageWithComponents_Coder

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

type MessageWithComponents_CombinePayload

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

type MessageWithComponents_FunctionSpec

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

type MessageWithComponents_ParDoPayload

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

type MessageWithComponents_Pcollection

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

type MessageWithComponents_Ptransform

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

type MessageWithComponents_ReadPayload

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

type MessageWithComponents_SdkFunctionSpec

type MessageWithComponents_SdkFunctionSpec struct {
	SdkFunctionSpec *SdkFunctionSpec `protobuf:"bytes,4,opt,name=sdk_function_spec,json=sdkFunctionSpec,oneof"`
}

type MessageWithComponents_SideInput

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

type MessageWithComponents_WindowIntoPayload

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

type MessageWithComponents_WindowingStrategy

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

type OAuth2ClientCredentialsGrant

type OAuth2ClientCredentialsGrant struct {
	// (Required) The URL to submit a "client_credentials" grant type request for
	// an OAuth access token which will be used as a bearer token for requests.
	Url string `protobuf:"bytes,1,opt,name=url" json:"url,omitempty"`
}

func (*OAuth2ClientCredentialsGrant) Descriptor

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

func (*OAuth2ClientCredentialsGrant) GetUrl

func (*OAuth2ClientCredentialsGrant) ProtoMessage

func (*OAuth2ClientCredentialsGrant) ProtoMessage()

func (*OAuth2ClientCredentialsGrant) Reset

func (m *OAuth2ClientCredentialsGrant) Reset()

func (*OAuth2ClientCredentialsGrant) String

type OnTimeBehavior

type OnTimeBehavior struct {
}

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

func (*OnTimeBehavior) Descriptor

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

func (*OnTimeBehavior) ProtoMessage

func (*OnTimeBehavior) ProtoMessage()

func (*OnTimeBehavior) Reset

func (m *OnTimeBehavior) Reset()

func (*OnTimeBehavior) String

func (m *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) EnumDescriptor

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

func (OnTimeBehavior_Enum) String

func (x OnTimeBehavior_Enum) String() string

type OutputTime

type OutputTime struct {
}

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

func (*OutputTime) Descriptor

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

func (*OutputTime) ProtoMessage

func (*OutputTime) ProtoMessage()

func (*OutputTime) Reset

func (m *OutputTime) Reset()

func (*OutputTime) String

func (m *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) EnumDescriptor

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

func (OutputTime_Enum) String

func (x OutputTime_Enum) String() string

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" json:"unique_name,omitempty"`
	// (Required) The id of the Coder for this PCollection.
	CoderId string `protobuf:"bytes,2,opt,name=coder_id,json=coderId" json:"coder_id,omitempty"`
	// (Required) Whether this PCollection is bounded or unbounded
	IsBounded IsBounded_Enum `` /* 136-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" json:"windowing_strategy_id,omitempty"`
	// (Optional) Static display data for this PTransform application. If
	// there is none, or it is not relevant (such as use by the Fn API)
	// then it may be omitted.
	DisplayData *DisplayData `protobuf:"bytes,5,opt,name=display_data,json=displayData" json:"display_data,omitempty"`
}

A PCollection!

func (*PCollection) Descriptor

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

func (*PCollection) GetCoderId

func (m *PCollection) GetCoderId() string

func (*PCollection) GetDisplayData

func (m *PCollection) GetDisplayData() *DisplayData

func (*PCollection) GetIsBounded

func (m *PCollection) GetIsBounded() IsBounded_Enum

func (*PCollection) GetUniqueName

func (m *PCollection) GetUniqueName() string

func (*PCollection) GetWindowingStrategyId

func (m *PCollection) GetWindowingStrategyId() string

func (*PCollection) ProtoMessage

func (*PCollection) ProtoMessage()

func (*PCollection) Reset

func (m *PCollection) Reset()

func (*PCollection) String

func (m *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" 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.
	//
	// TODO: document the standardized URNs and payloads
	// TODO: separate standardized payloads into a separate proto file
	//
	// For some special composite transforms, the payload is also officially
	// defined:
	//
	//  - when the URN is "urn:beam:transforms:combine" it is a CombinePayload
	//
	Spec *FunctionSpec `protobuf:"bytes,1,opt,name=spec" json:"spec,omitempty"`
	// (Optional) if this node is a composite, a list of the ids of
	// transforms that it contains.
	Subtransforms []string `protobuf:"bytes,2,rep,name=subtransforms" 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 `` /* 132-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 `` /* 134-byte string literal not displayed */
	// (Optional) Static display data for this PTransform application. If
	// there is none, or it is not relevant (such as use by the Fn API)
	// then it may be omitted.
	DisplayData *DisplayData `protobuf:"bytes,6,opt,name=display_data,json=displayData" json:"display_data,omitempty"`
}

An applied PTransform! This does not contain the graph data, but only the fields specific to a graph node that is a Runner API transform between PCollections.

func (*PTransform) Descriptor

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

func (*PTransform) GetDisplayData

func (m *PTransform) GetDisplayData() *DisplayData

func (*PTransform) GetInputs

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

func (*PTransform) GetOutputs

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

func (*PTransform) GetSpec

func (m *PTransform) GetSpec() *FunctionSpec

func (*PTransform) GetSubtransforms

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

func (*PTransform) GetUniqueName

func (m *PTransform) GetUniqueName() string

func (*PTransform) ProtoMessage

func (*PTransform) ProtoMessage()

func (*PTransform) Reset

func (m *PTransform) Reset()

func (*PTransform) String

func (m *PTransform) String() string

type ParDoPayload

type ParDoPayload struct {
	// (Required) The SdkFunctionSpec of the DoFn.
	DoFn *SdkFunctionSpec `protobuf:"bytes,1,opt,name=do_fn,json=doFn" json:"do_fn,omitempty"`
	// (Required) Additional pieces of context the DoFn may require that
	// are not otherwise represented in the payload.
	// (may force runners to execute the ParDo differently)
	Parameters []*Parameter `protobuf:"bytes,2,rep,name=parameters" json:"parameters,omitempty"`
	// (Optional) A mapping of local input names to side inputs, describing
	// the expected access pattern.
	SideInputs map[string]*SideInput `` /* 158-byte string literal not displayed */
	// (Optional) A mapping of local state names to state specifications.
	StateSpecs map[string]*StateSpec `` /* 158-byte string literal not displayed */
	// (Optional) A mapping of local timer names to timer specifications.
	TimerSpecs map[string]*TimerSpec `` /* 158-byte string literal not displayed */
	// Whether the DoFn is splittable
	Splittable bool `protobuf:"varint,6,opt,name=splittable" json:"splittable,omitempty"`
}

The payload for the primitive ParDo transform.

func (*ParDoPayload) Descriptor

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

func (*ParDoPayload) GetDoFn

func (m *ParDoPayload) GetDoFn() *SdkFunctionSpec

func (*ParDoPayload) GetParameters

func (m *ParDoPayload) GetParameters() []*Parameter

func (*ParDoPayload) GetSideInputs

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

func (*ParDoPayload) GetSplittable

func (m *ParDoPayload) GetSplittable() bool

func (*ParDoPayload) GetStateSpecs

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

func (*ParDoPayload) GetTimerSpecs

func (m *ParDoPayload) GetTimerSpecs() map[string]*TimerSpec

func (*ParDoPayload) ProtoMessage

func (*ParDoPayload) ProtoMessage()

func (*ParDoPayload) Reset

func (m *ParDoPayload) Reset()

func (*ParDoPayload) String

func (m *ParDoPayload) String() string

type Parameter

type Parameter struct {
	Type Parameter_Type_Enum `protobuf:"varint,1,opt,name=type,enum=org.apache.beam.model.pipeline.v1.Parameter_Type_Enum" json:"type,omitempty"`
}

Parameters that a UDF might require.

The details of how a runner sends these parameters to the SDK harness are the subject of the Fn API.

The details of how an SDK harness delivers them to the UDF is entirely up to the SDK. (for some SDKs there may be parameters that are not represented here if the runner doesn't need to do anything)

Here, the parameters are simply indicators to the runner that they need to run the function a particular way.

TODO: the evolution of the Fn API will influence what needs explicit representation here

func (*Parameter) Descriptor

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

func (*Parameter) GetType

func (m *Parameter) GetType() Parameter_Type_Enum

func (*Parameter) ProtoMessage

func (*Parameter) ProtoMessage()

func (*Parameter) Reset

func (m *Parameter) Reset()

func (*Parameter) String

func (m *Parameter) String() string

type Parameter_Type

type Parameter_Type struct {
}

func (*Parameter_Type) Descriptor

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

func (*Parameter_Type) ProtoMessage

func (*Parameter_Type) ProtoMessage()

func (*Parameter_Type) Reset

func (m *Parameter_Type) Reset()

func (*Parameter_Type) String

func (m *Parameter_Type) String() string

type Parameter_Type_Enum

type Parameter_Type_Enum int32
const (
	Parameter_Type_UNSPECIFIED         Parameter_Type_Enum = 0
	Parameter_Type_WINDOW              Parameter_Type_Enum = 1
	Parameter_Type_PIPELINE_OPTIONS    Parameter_Type_Enum = 2
	Parameter_Type_RESTRICTION_TRACKER Parameter_Type_Enum = 3
)

func (Parameter_Type_Enum) EnumDescriptor

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

func (Parameter_Type_Enum) String

func (x Parameter_Type_Enum) 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" 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" 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,opt,name=display_data,json=displayData" json:"display_data,omitempty"`
}

A Pipeline is a hierarchical graph of PTransforms, linked by PCollections.

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

All of the keys in the maps here are arbitrary strings that are only required to be internally consistent within this proto message.

func (*Pipeline) Descriptor

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

func (*Pipeline) GetComponents

func (m *Pipeline) GetComponents() *Components

func (*Pipeline) GetDisplayData

func (m *Pipeline) GetDisplayData() *DisplayData

func (*Pipeline) GetRootTransformIds

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

func (*Pipeline) ProtoMessage

func (*Pipeline) ProtoMessage()

func (*Pipeline) Reset

func (m *Pipeline) Reset()

func (*Pipeline) String

func (m *Pipeline) String() string

type ReadPayload

type ReadPayload struct {
	// (Required) The SdkFunctionSpec of the source for this Read.
	Source *SdkFunctionSpec `protobuf:"bytes,1,opt,name=source" json:"source,omitempty"`
	// (Required) Whether the source is bounded or unbounded
	IsBounded IsBounded_Enum `` /* 136-byte string literal not displayed */
}

The payload for the primitive Read transform.

func (*ReadPayload) Descriptor

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

func (*ReadPayload) GetIsBounded

func (m *ReadPayload) GetIsBounded() IsBounded_Enum

func (*ReadPayload) GetSource

func (m *ReadPayload) GetSource() *SdkFunctionSpec

func (*ReadPayload) ProtoMessage

func (*ReadPayload) ProtoMessage()

func (*ReadPayload) Reset

func (m *ReadPayload) Reset()

func (*ReadPayload) String

func (m *ReadPayload) String() string

type SdkFunctionSpec

type SdkFunctionSpec struct {
	// (Required) A full specification of this function.
	Spec *FunctionSpec `protobuf:"bytes,1,opt,name=spec" json:"spec,omitempty"`
	// (Required) Reference to an execution environment capable of
	// invoking this function.
	EnvironmentId string `protobuf:"bytes,2,opt,name=environment_id,json=environmentId" json:"environment_id,omitempty"`
}

A specification of a user defined function.

func (*SdkFunctionSpec) Descriptor

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

func (*SdkFunctionSpec) GetEnvironmentId

func (m *SdkFunctionSpec) GetEnvironmentId() string

func (*SdkFunctionSpec) GetSpec

func (m *SdkFunctionSpec) GetSpec() *FunctionSpec

func (*SdkFunctionSpec) ProtoMessage

func (*SdkFunctionSpec) ProtoMessage()

func (*SdkFunctionSpec) Reset

func (m *SdkFunctionSpec) Reset()

func (*SdkFunctionSpec) String

func (m *SdkFunctionSpec) String() string

type SessionsPayload

type SessionsPayload struct {
	GapSize *google_protobuf1.Duration `protobuf:"bytes,1,opt,name=gap_size,json=gapSize" json:"gap_size,omitempty"`
}

beam:windowfn:session_windows:v0.1

func (*SessionsPayload) Descriptor

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

func (*SessionsPayload) GetGapSize

func (m *SessionsPayload) GetGapSize() *google_protobuf1.Duration

func (*SessionsPayload) ProtoMessage

func (*SessionsPayload) ProtoMessage()

func (*SessionsPayload) Reset

func (m *SessionsPayload) Reset()

func (*SessionsPayload) String

func (m *SessionsPayload) String() string

type SetStateSpec

type SetStateSpec struct {
	ElementCoderId string `protobuf:"bytes,1,opt,name=element_coder_id,json=elementCoderId" json:"element_coder_id,omitempty"`
}

func (*SetStateSpec) Descriptor

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

func (*SetStateSpec) GetElementCoderId

func (m *SetStateSpec) GetElementCoderId() string

func (*SetStateSpec) ProtoMessage

func (*SetStateSpec) ProtoMessage()

func (*SetStateSpec) Reset

func (m *SetStateSpec) Reset()

func (*SetStateSpec) String

func (m *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 "urn:beam:sideinput:multimap" (or some such
	// URN)
	AccessPattern *FunctionSpec `protobuf:"bytes,1,opt,name=access_pattern,json=accessPattern" json:"access_pattern,omitempty"`
	// (Required) The SdkFunctionSpec 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 *SdkFunctionSpec `protobuf:"bytes,2,opt,name=view_fn,json=viewFn" json:"view_fn,omitempty"`
	// (Required) The SdkFunctionSpec 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 *SdkFunctionSpec `protobuf:"bytes,3,opt,name=window_mapping_fn,json=windowMappingFn" json:"window_mapping_fn,omitempty"`
}

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

func (*SideInput) Descriptor

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

func (*SideInput) GetAccessPattern

func (m *SideInput) GetAccessPattern() *FunctionSpec

func (*SideInput) GetViewFn

func (m *SideInput) GetViewFn() *SdkFunctionSpec

func (*SideInput) GetWindowMappingFn

func (m *SideInput) GetWindowMappingFn() *SdkFunctionSpec

func (*SideInput) ProtoMessage

func (*SideInput) ProtoMessage()

func (*SideInput) Reset

func (m *SideInput) Reset()

func (*SideInput) String

func (m *SideInput) String() string

type SlidingWindowsPayload

type SlidingWindowsPayload struct {
	Size   *google_protobuf1.Duration  `protobuf:"bytes,1,opt,name=size" json:"size,omitempty"`
	Offset *google_protobuf2.Timestamp `protobuf:"bytes,2,opt,name=offset" json:"offset,omitempty"`
	Period *google_protobuf1.Duration  `protobuf:"bytes,3,opt,name=period" json:"period,omitempty"`
}

beam:windowfn:sliding_windows:v0.1

func (*SlidingWindowsPayload) Descriptor

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

func (*SlidingWindowsPayload) GetOffset

func (*SlidingWindowsPayload) GetPeriod

func (*SlidingWindowsPayload) GetSize

func (*SlidingWindowsPayload) ProtoMessage

func (*SlidingWindowsPayload) ProtoMessage()

func (*SlidingWindowsPayload) Reset

func (m *SlidingWindowsPayload) Reset()

func (*SlidingWindowsPayload) String

func (m *SlidingWindowsPayload) String() string

type StateSpec

type StateSpec struct {
	// Types that are valid to be assigned to Spec:
	//	*StateSpec_ValueSpec
	//	*StateSpec_BagSpec
	//	*StateSpec_CombiningSpec
	//	*StateSpec_MapSpec
	//	*StateSpec_SetSpec
	Spec isStateSpec_Spec `protobuf_oneof:"spec"`
}

func (*StateSpec) Descriptor

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

func (*StateSpec) GetBagSpec

func (m *StateSpec) GetBagSpec() *BagStateSpec

func (*StateSpec) GetCombiningSpec

func (m *StateSpec) GetCombiningSpec() *CombiningStateSpec

func (*StateSpec) GetMapSpec

func (m *StateSpec) GetMapSpec() *MapStateSpec

func (*StateSpec) GetSetSpec

func (m *StateSpec) GetSetSpec() *SetStateSpec

func (*StateSpec) GetSpec

func (m *StateSpec) GetSpec() isStateSpec_Spec

func (*StateSpec) GetValueSpec

func (m *StateSpec) GetValueSpec() *ValueStateSpec

func (*StateSpec) ProtoMessage

func (*StateSpec) ProtoMessage()

func (*StateSpec) Reset

func (m *StateSpec) Reset()

func (*StateSpec) String

func (m *StateSpec) String() string

func (*StateSpec) XXX_OneofFuncs

func (*StateSpec) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, func(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error), func(msg proto.Message) (n int), []interface{})

XXX_OneofFuncs is for the internal use of the proto package.

type StateSpec_BagSpec

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

type StateSpec_CombiningSpec

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

type StateSpec_MapSpec

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

type StateSpec_SetSpec

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

type StateSpec_ValueSpec

type StateSpec_ValueSpec struct {
	ValueSpec *ValueStateSpec `protobuf:"bytes,1,opt,name=value_spec,json=valueSpec,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" json:"coder_id,omitempty"`
	Events  []*TestStreamPayload_Event `protobuf:"bytes,2,rep,name=events" json:"events,omitempty"`
}

The payload for the test-only primitive TestStream

func (*TestStreamPayload) Descriptor

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

func (*TestStreamPayload) GetCoderId

func (m *TestStreamPayload) GetCoderId() string

func (*TestStreamPayload) GetEvents

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

func (*TestStreamPayload) ProtoMessage

func (*TestStreamPayload) ProtoMessage()

func (*TestStreamPayload) Reset

func (m *TestStreamPayload) Reset()

func (*TestStreamPayload) String

func (m *TestStreamPayload) String() string

type TestStreamPayload_Event

type TestStreamPayload_Event struct {
	// Types that are valid to be assigned to Event:
	//	*TestStreamPayload_Event_WatermarkEvent
	//	*TestStreamPayload_Event_ProcessingTimeEvent
	//	*TestStreamPayload_Event_ElementEvent
	Event isTestStreamPayload_Event_Event `protobuf_oneof:"event"`
}

func (*TestStreamPayload_Event) Descriptor

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

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) Reset

func (m *TestStreamPayload_Event) Reset()

func (*TestStreamPayload_Event) String

func (m *TestStreamPayload_Event) String() string

func (*TestStreamPayload_Event) XXX_OneofFuncs

func (*TestStreamPayload_Event) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, func(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error), func(msg proto.Message) (n int), []interface{})

XXX_OneofFuncs is for the internal use of the proto package.

type TestStreamPayload_Event_AddElements

type TestStreamPayload_Event_AddElements struct {
	Elements []*TestStreamPayload_TimestampedElement `protobuf:"bytes,1,rep,name=elements" json:"elements,omitempty"`
}

func (*TestStreamPayload_Event_AddElements) Descriptor

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

func (*TestStreamPayload_Event_AddElements) GetElements

func (*TestStreamPayload_Event_AddElements) ProtoMessage

func (*TestStreamPayload_Event_AddElements) ProtoMessage()

func (*TestStreamPayload_Event_AddElements) Reset

func (*TestStreamPayload_Event_AddElements) String

type TestStreamPayload_Event_AdvanceProcessingTime

type TestStreamPayload_Event_AdvanceProcessingTime struct {
	AdvanceDuration int64 `protobuf:"varint,1,opt,name=advance_duration,json=advanceDuration" json:"advance_duration,omitempty"`
}

func (*TestStreamPayload_Event_AdvanceProcessingTime) Descriptor

func (*TestStreamPayload_Event_AdvanceProcessingTime) GetAdvanceDuration

func (m *TestStreamPayload_Event_AdvanceProcessingTime) GetAdvanceDuration() int64

func (*TestStreamPayload_Event_AdvanceProcessingTime) ProtoMessage

func (*TestStreamPayload_Event_AdvanceProcessingTime) Reset

func (*TestStreamPayload_Event_AdvanceProcessingTime) String

type TestStreamPayload_Event_AdvanceWatermark

type TestStreamPayload_Event_AdvanceWatermark struct {
	NewWatermark int64 `protobuf:"varint,1,opt,name=new_watermark,json=newWatermark" json:"new_watermark,omitempty"`
}

func (*TestStreamPayload_Event_AdvanceWatermark) Descriptor

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

func (*TestStreamPayload_Event_AdvanceWatermark) GetNewWatermark

func (m *TestStreamPayload_Event_AdvanceWatermark) GetNewWatermark() int64

func (*TestStreamPayload_Event_AdvanceWatermark) ProtoMessage

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,oneof"`
}

type TestStreamPayload_Event_ProcessingTimeEvent

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

type TestStreamPayload_Event_WatermarkEvent

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

type TestStreamPayload_TimestampedElement

type TestStreamPayload_TimestampedElement struct {
	EncodedElement []byte `protobuf:"bytes,1,opt,name=encoded_element,json=encodedElement,proto3" json:"encoded_element,omitempty"`
	Timestamp      int64  `protobuf:"varint,2,opt,name=timestamp" json:"timestamp,omitempty"`
}

func (*TestStreamPayload_TimestampedElement) Descriptor

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

func (*TestStreamPayload_TimestampedElement) GetEncodedElement

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

func (*TestStreamPayload_TimestampedElement) GetTimestamp

func (m *TestStreamPayload_TimestampedElement) GetTimestamp() int64

func (*TestStreamPayload_TimestampedElement) ProtoMessage

func (*TestStreamPayload_TimestampedElement) ProtoMessage()

func (*TestStreamPayload_TimestampedElement) Reset

func (*TestStreamPayload_TimestampedElement) String

type TimeDomain

type TimeDomain struct {
}

The different time domains in the Beam model.

func (*TimeDomain) Descriptor

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

func (*TimeDomain) ProtoMessage

func (*TimeDomain) ProtoMessage()

func (*TimeDomain) Reset

func (m *TimeDomain) Reset()

func (*TimeDomain) String

func (m *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
	// Synchronized processing time is the minimum of the
	// processing time of all pending elements.
	//
	// The "processing time" of an element refers to
	// the local processing time at which it was emitted
	TimeDomain_SYNCHRONIZED_PROCESSING_TIME TimeDomain_Enum = 3
)

func (TimeDomain_Enum) EnumDescriptor

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

func (TimeDomain_Enum) String

func (x TimeDomain_Enum) String() string

type TimerSpec

type TimerSpec struct {
	TimeDomain TimeDomain_Enum `` /* 140-byte string literal not displayed */
}

func (*TimerSpec) Descriptor

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

func (*TimerSpec) GetTimeDomain

func (m *TimerSpec) GetTimeDomain() TimeDomain_Enum

func (*TimerSpec) ProtoMessage

func (*TimerSpec) ProtoMessage()

func (*TimerSpec) Reset

func (m *TimerSpec) Reset()

func (*TimerSpec) String

func (m *TimerSpec) String() string

type TimestampTransform

type TimestampTransform struct {
	// Types that are valid to be assigned to TimestampTransform:
	//	*TimestampTransform_Delay_
	//	*TimestampTransform_AlignTo_
	TimestampTransform isTimestampTransform_TimestampTransform `protobuf_oneof:"timestamp_transform"`
}

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

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

func (*TimestampTransform) GetAlignTo

func (*TimestampTransform) GetDelay

func (*TimestampTransform) GetTimestampTransform

func (m *TimestampTransform) GetTimestampTransform() isTimestampTransform_TimestampTransform

func (*TimestampTransform) ProtoMessage

func (*TimestampTransform) ProtoMessage()

func (*TimestampTransform) Reset

func (m *TimestampTransform) Reset()

func (*TimestampTransform) String

func (m *TimestampTransform) String() string

func (*TimestampTransform) XXX_OneofFuncs

func (*TimestampTransform) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, func(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error), func(msg proto.Message) (n int), []interface{})

XXX_OneofFuncs is for the internal use of the proto package.

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" 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" json:"offset,omitempty"`
}

func (*TimestampTransform_AlignTo) Descriptor

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

func (*TimestampTransform_AlignTo) GetOffset

func (m *TimestampTransform_AlignTo) GetOffset() int64

func (*TimestampTransform_AlignTo) GetPeriod

func (m *TimestampTransform_AlignTo) GetPeriod() int64

func (*TimestampTransform_AlignTo) ProtoMessage

func (*TimestampTransform_AlignTo) ProtoMessage()

func (*TimestampTransform_AlignTo) Reset

func (m *TimestampTransform_AlignTo) Reset()

func (*TimestampTransform_AlignTo) String

func (m *TimestampTransform_AlignTo) String() string

type TimestampTransform_AlignTo_

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

type TimestampTransform_Delay

type TimestampTransform_Delay struct {
	// (Required) The delay, in milliseconds.
	DelayMillis int64 `protobuf:"varint,1,opt,name=delay_millis,json=delayMillis" json:"delay_millis,omitempty"`
}

func (*TimestampTransform_Delay) Descriptor

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

func (*TimestampTransform_Delay) GetDelayMillis

func (m *TimestampTransform_Delay) GetDelayMillis() int64

func (*TimestampTransform_Delay) ProtoMessage

func (*TimestampTransform_Delay) ProtoMessage()

func (*TimestampTransform_Delay) Reset

func (m *TimestampTransform_Delay) Reset()

func (*TimestampTransform_Delay) String

func (m *TimestampTransform_Delay) String() string

type TimestampTransform_Delay_

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

type Trigger

type Trigger struct {
	// The full disjoint union of possible triggers.
	//
	// Types that are valid to be assigned 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"`
}

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

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

func (*Trigger) GetAfterAll

func (m *Trigger) GetAfterAll() *Trigger_AfterAll

func (*Trigger) GetAfterAny

func (m *Trigger) GetAfterAny() *Trigger_AfterAny

func (*Trigger) GetAfterEach

func (m *Trigger) GetAfterEach() *Trigger_AfterEach

func (*Trigger) GetAfterEndOfWindow

func (m *Trigger) GetAfterEndOfWindow() *Trigger_AfterEndOfWindow

func (*Trigger) GetAfterProcessingTime

func (m *Trigger) GetAfterProcessingTime() *Trigger_AfterProcessingTime

func (*Trigger) GetAfterSynchronizedProcessingTime

func (m *Trigger) GetAfterSynchronizedProcessingTime() *Trigger_AfterSynchronizedProcessingTime

func (*Trigger) GetAlways

func (m *Trigger) GetAlways() *Trigger_Always

func (*Trigger) GetDefault

func (m *Trigger) GetDefault() *Trigger_Default

func (*Trigger) GetElementCount

func (m *Trigger) GetElementCount() *Trigger_ElementCount

func (*Trigger) GetNever

func (m *Trigger) GetNever() *Trigger_Never

func (*Trigger) GetOrFinally

func (m *Trigger) GetOrFinally() *Trigger_OrFinally

func (*Trigger) GetRepeat

func (m *Trigger) GetRepeat() *Trigger_Repeat

func (*Trigger) GetTrigger

func (m *Trigger) GetTrigger() isTrigger_Trigger

func (*Trigger) ProtoMessage

func (*Trigger) ProtoMessage()

func (*Trigger) Reset

func (m *Trigger) Reset()

func (*Trigger) String

func (m *Trigger) String() string

func (*Trigger) XXX_OneofFuncs

func (*Trigger) XXX_OneofFuncs() (func(msg proto.Message, b *proto.Buffer) error, func(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error), func(msg proto.Message) (n int), []interface{})

XXX_OneofFuncs is for the internal use of the proto package.

type Trigger_AfterAll

type Trigger_AfterAll struct {
	Subtriggers []*Trigger `protobuf:"bytes,1,rep,name=subtriggers" json:"subtriggers,omitempty"`
}

Ready when all subtriggers are ready.

func (*Trigger_AfterAll) Descriptor

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

func (*Trigger_AfterAll) GetSubtriggers

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

func (*Trigger_AfterAll) ProtoMessage

func (*Trigger_AfterAll) ProtoMessage()

func (*Trigger_AfterAll) Reset

func (m *Trigger_AfterAll) Reset()

func (*Trigger_AfterAll) String

func (m *Trigger_AfterAll) String() string

type Trigger_AfterAll_

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

type Trigger_AfterAny

type Trigger_AfterAny struct {
	Subtriggers []*Trigger `protobuf:"bytes,1,rep,name=subtriggers" json:"subtriggers,omitempty"`
}

Ready when any subtrigger is ready.

func (*Trigger_AfterAny) Descriptor

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

func (*Trigger_AfterAny) GetSubtriggers

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

func (*Trigger_AfterAny) ProtoMessage

func (*Trigger_AfterAny) ProtoMessage()

func (*Trigger_AfterAny) Reset

func (m *Trigger_AfterAny) Reset()

func (*Trigger_AfterAny) String

func (m *Trigger_AfterAny) String() string

type Trigger_AfterAny_

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

type Trigger_AfterEach

type Trigger_AfterEach struct {
	Subtriggers []*Trigger `protobuf:"bytes,1,rep,name=subtriggers" json:"subtriggers,omitempty"`
}

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

func (*Trigger_AfterEach) Descriptor

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

func (*Trigger_AfterEach) GetSubtriggers

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

func (*Trigger_AfterEach) ProtoMessage

func (*Trigger_AfterEach) ProtoMessage()

func (*Trigger_AfterEach) Reset

func (m *Trigger_AfterEach) Reset()

func (*Trigger_AfterEach) String

func (m *Trigger_AfterEach) String() string

type Trigger_AfterEach_

type Trigger_AfterEach_ struct {
	AfterEach *Trigger_AfterEach `protobuf:"bytes,3,opt,name=after_each,json=afterEach,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" 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" json:"late_firings,omitempty"`
}

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

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

func (*Trigger_AfterEndOfWindow) GetEarlyFirings

func (m *Trigger_AfterEndOfWindow) GetEarlyFirings() *Trigger

func (*Trigger_AfterEndOfWindow) GetLateFirings

func (m *Trigger_AfterEndOfWindow) GetLateFirings() *Trigger

func (*Trigger_AfterEndOfWindow) ProtoMessage

func (*Trigger_AfterEndOfWindow) ProtoMessage()

func (*Trigger_AfterEndOfWindow) Reset

func (m *Trigger_AfterEndOfWindow) Reset()

func (*Trigger_AfterEndOfWindow) String

func (m *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,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" json:"timestamp_transforms,omitempty"`
}

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

func (*Trigger_AfterProcessingTime) Descriptor

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

func (*Trigger_AfterProcessingTime) GetTimestampTransforms

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

func (*Trigger_AfterProcessingTime) ProtoMessage

func (*Trigger_AfterProcessingTime) ProtoMessage()

func (*Trigger_AfterProcessingTime) Reset

func (m *Trigger_AfterProcessingTime) Reset()

func (*Trigger_AfterProcessingTime) String

func (m *Trigger_AfterProcessingTime) String() string

type Trigger_AfterProcessingTime_

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

type Trigger_AfterSynchronizedProcessingTime

type Trigger_AfterSynchronizedProcessingTime struct {
}

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

func (*Trigger_AfterSynchronizedProcessingTime) Descriptor

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

func (*Trigger_AfterSynchronizedProcessingTime) ProtoMessage

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,oneof"`
}

type Trigger_Always

type Trigger_Always struct {
}

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

func (*Trigger_Always) Descriptor

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

func (*Trigger_Always) ProtoMessage

func (*Trigger_Always) ProtoMessage()

func (*Trigger_Always) Reset

func (m *Trigger_Always) Reset()

func (*Trigger_Always) String

func (m *Trigger_Always) String() string

type Trigger_Always_

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

type Trigger_Default

type Trigger_Default struct {
}

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

func (*Trigger_Default) Descriptor

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

func (*Trigger_Default) ProtoMessage

func (*Trigger_Default) ProtoMessage()

func (*Trigger_Default) Reset

func (m *Trigger_Default) Reset()

func (*Trigger_Default) String

func (m *Trigger_Default) String() string

type Trigger_Default_

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

type Trigger_ElementCount

type Trigger_ElementCount struct {
	ElementCount int32 `protobuf:"varint,1,opt,name=element_count,json=elementCount" json:"element_count,omitempty"`
}

Ready whenever the requisite number of input elements have arrived

func (*Trigger_ElementCount) Descriptor

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

func (*Trigger_ElementCount) GetElementCount

func (m *Trigger_ElementCount) GetElementCount() int32

func (*Trigger_ElementCount) ProtoMessage

func (*Trigger_ElementCount) ProtoMessage()

func (*Trigger_ElementCount) Reset

func (m *Trigger_ElementCount) Reset()

func (*Trigger_ElementCount) String

func (m *Trigger_ElementCount) String() string

type Trigger_ElementCount_

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

type Trigger_Never

type Trigger_Never struct {
}

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

func (*Trigger_Never) Descriptor

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

func (*Trigger_Never) ProtoMessage

func (*Trigger_Never) ProtoMessage()

func (*Trigger_Never) Reset

func (m *Trigger_Never) Reset()

func (*Trigger_Never) String

func (m *Trigger_Never) String() string

type Trigger_Never_

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

type Trigger_OrFinally

type Trigger_OrFinally struct {
	// (Required) Trigger governing main output; may fire repeatedly.
	Main *Trigger `protobuf:"bytes,1,opt,name=main" json:"main,omitempty"`
	// (Required) Trigger governing termination of output.
	Finally *Trigger `protobuf:"bytes,2,opt,name=finally" json:"finally,omitempty"`
}

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

func (*Trigger_OrFinally) Descriptor

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

func (*Trigger_OrFinally) GetFinally

func (m *Trigger_OrFinally) GetFinally() *Trigger

func (*Trigger_OrFinally) GetMain

func (m *Trigger_OrFinally) GetMain() *Trigger

func (*Trigger_OrFinally) ProtoMessage

func (*Trigger_OrFinally) ProtoMessage()

func (*Trigger_OrFinally) Reset

func (m *Trigger_OrFinally) Reset()

func (*Trigger_OrFinally) String

func (m *Trigger_OrFinally) String() string

type Trigger_OrFinally_

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

type Trigger_Repeat

type Trigger_Repeat struct {
	// (Require) Trigger that is run repeatedly.
	Subtrigger *Trigger `protobuf:"bytes,1,opt,name=subtrigger" json:"subtrigger,omitempty"`
}

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

func (*Trigger_Repeat) Descriptor

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

func (*Trigger_Repeat) GetSubtrigger

func (m *Trigger_Repeat) GetSubtrigger() *Trigger

func (*Trigger_Repeat) ProtoMessage

func (*Trigger_Repeat) ProtoMessage()

func (*Trigger_Repeat) Reset

func (m *Trigger_Repeat) Reset()

func (*Trigger_Repeat) String

func (m *Trigger_Repeat) String() string

type Trigger_Repeat_

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

type ValueStateSpec

type ValueStateSpec struct {
	CoderId string `protobuf:"bytes,1,opt,name=coder_id,json=coderId" json:"coder_id,omitempty"`
}

func (*ValueStateSpec) Descriptor

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

func (*ValueStateSpec) GetCoderId

func (m *ValueStateSpec) GetCoderId() string

func (*ValueStateSpec) ProtoMessage

func (*ValueStateSpec) ProtoMessage()

func (*ValueStateSpec) Reset

func (m *ValueStateSpec) Reset()

func (*ValueStateSpec) String

func (m *ValueStateSpec) String() string

type WindowIntoPayload

type WindowIntoPayload struct {
	// (Required) The SdkFunctionSpec of the WindowFn.
	WindowFn *SdkFunctionSpec `protobuf:"bytes,1,opt,name=window_fn,json=windowFn" json:"window_fn,omitempty"`
}

The payload for the WindowInto transform.

func (*WindowIntoPayload) Descriptor

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

func (*WindowIntoPayload) GetWindowFn

func (m *WindowIntoPayload) GetWindowFn() *SdkFunctionSpec

func (*WindowIntoPayload) ProtoMessage

func (*WindowIntoPayload) ProtoMessage()

func (*WindowIntoPayload) Reset

func (m *WindowIntoPayload) Reset()

func (*WindowIntoPayload) String

func (m *WindowIntoPayload) String() string

type WindowingStrategy

type WindowingStrategy struct {
	// (Required) The SdkFunctionSpec of the UDF that assigns windows,
	// merges windows, and shifts timestamps before they are
	// combined according to the OutputTime.
	WindowFn *SdkFunctionSpec `protobuf:"bytes,1,opt,name=window_fn,json=windowFn" json:"window_fn,omitempty"`
	// (Required) Whether or not the window fn is merging.
	//
	// This knowledge is required for many optimizations.
	MergeStatus MergeStatus_Enum `` /* 144-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" json:"window_coder_id,omitempty"`
	// (Required) The trigger to use when grouping this PCollection.
	Trigger *Trigger `protobuf:"bytes,4,opt,name=trigger" 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 `` /* 164-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 `` /* 140-byte string literal not displayed */
	// (Required) Indicate when output should be omitted upon window expiration.
	ClosingBehavior ClosingBehavior_Enum `` /* 160-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" json:"allowed_lateness,omitempty"`
	// (Required) Indicate whether empty on-time panes should be omitted.
	OnTimeBehavior OnTimeBehavior_Enum `` /* 134-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" json:"assigns_to_one_window,omitempty"`
}

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

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

func (*WindowingStrategy) GetAccumulationMode

func (m *WindowingStrategy) GetAccumulationMode() AccumulationMode_Enum

func (*WindowingStrategy) GetAllowedLateness

func (m *WindowingStrategy) GetAllowedLateness() int64

func (*WindowingStrategy) GetAssignsToOneWindow

func (m *WindowingStrategy) GetAssignsToOneWindow() bool

func (*WindowingStrategy) GetClosingBehavior

func (m *WindowingStrategy) GetClosingBehavior() ClosingBehavior_Enum

func (*WindowingStrategy) GetMergeStatus

func (m *WindowingStrategy) GetMergeStatus() MergeStatus_Enum

func (*WindowingStrategy) GetOnTimeBehavior

func (m *WindowingStrategy) GetOnTimeBehavior() OnTimeBehavior_Enum

func (*WindowingStrategy) GetOutputTime

func (m *WindowingStrategy) GetOutputTime() OutputTime_Enum

func (*WindowingStrategy) GetTrigger

func (m *WindowingStrategy) GetTrigger() *Trigger

func (*WindowingStrategy) GetWindowCoderId

func (m *WindowingStrategy) GetWindowCoderId() string

func (*WindowingStrategy) GetWindowFn

func (m *WindowingStrategy) GetWindowFn() *SdkFunctionSpec

func (*WindowingStrategy) ProtoMessage

func (*WindowingStrategy) ProtoMessage()

func (*WindowingStrategy) Reset

func (m *WindowingStrategy) Reset()

func (*WindowingStrategy) String

func (m *WindowingStrategy) String() string

type WriteFilesPayload

type WriteFilesPayload struct {
	// (Required) The SdkFunctionSpec of the FileBasedSink.
	Sink *SdkFunctionSpec `protobuf:"bytes,1,opt,name=sink" json:"sink,omitempty"`
	// (Required) The format function.
	FormatFunction           *SdkFunctionSpec      `protobuf:"bytes,2,opt,name=format_function,json=formatFunction" json:"format_function,omitempty"`
	WindowedWrites           bool                  `protobuf:"varint,3,opt,name=windowed_writes,json=windowedWrites" json:"windowed_writes,omitempty"`
	RunnerDeterminedSharding bool                  `` /* 129-byte string literal not displayed */
	SideInputs               map[string]*SideInput `` /* 158-byte string literal not displayed */
}

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

func (*WriteFilesPayload) Descriptor

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

func (*WriteFilesPayload) GetFormatFunction

func (m *WriteFilesPayload) GetFormatFunction() *SdkFunctionSpec

func (*WriteFilesPayload) GetRunnerDeterminedSharding

func (m *WriteFilesPayload) GetRunnerDeterminedSharding() bool

func (*WriteFilesPayload) GetSideInputs

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

func (*WriteFilesPayload) GetSink

func (m *WriteFilesPayload) GetSink() *SdkFunctionSpec

func (*WriteFilesPayload) GetWindowedWrites

func (m *WriteFilesPayload) GetWindowedWrites() bool

func (*WriteFilesPayload) ProtoMessage

func (*WriteFilesPayload) ProtoMessage()

func (*WriteFilesPayload) Reset

func (m *WriteFilesPayload) Reset()

func (*WriteFilesPayload) String

func (m *WriteFilesPayload) String() string

Jump to

Keyboard shortcuts

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