Skip to content

Commit

Permalink
Switch go todos from issue # syntax to links (apache#21890)
Browse files Browse the repository at this point in the history
  • Loading branch information
damccorm authored and prodriguezdefino committed Jun 21, 2022
1 parent f910091 commit ab256c5
Show file tree
Hide file tree
Showing 32 changed files with 53 additions and 53 deletions.
2 changes: 1 addition & 1 deletion sdks/go/container/boot.go
Original file line number Diff line number Diff line change
Expand Up @@ -135,7 +135,7 @@ func getGoWorkerArtifactName(artifacts []*pipepb.ArtifactInformation) (string, e
return name, nil
}
}
// TODO(Issue 21459): Remove legacy hack once aged out.
// TODO(https://github.com/apache/beam/issues/21459): Remove legacy hack once aged out.
for _, a := range artifacts {
n, _ := artifact.MustExtractFilePayload(a)
if n == worker {
Expand Down
4 changes: 2 additions & 2 deletions sdks/go/pkg/beam/artifact/materialize.go
Original file line number Diff line number Diff line change
Expand Up @@ -55,8 +55,8 @@ const (
// present and uncorrupted. It interprets each artifact name as a relative
// path under the dest directory. It does not retrieve valid artifacts already
// present.
// TODO(Issue 20267): Return a mapping of filename to dependency, rather than []*jobpb.ArtifactMetadata.
// TODO(Issue 20267): Leverage richness of roles rather than magic names to understand artifacts.
// TODO(https://github.com/apache/beam/issues/20267): Return a mapping of filename to dependency, rather than []*jobpb.ArtifactMetadata.
// TODO(https://github.com/apache/beam/issues/20267): Leverage richness of roles rather than magic names to understand artifacts.
func Materialize(ctx context.Context, endpoint string, dependencies []*pipepb.ArtifactInformation, rt string, dest string) ([]*pipepb.ArtifactInformation, error) {
if len(dependencies) > 0 {
return newMaterialize(ctx, endpoint, dependencies, dest)
Expand Down
4 changes: 2 additions & 2 deletions sdks/go/pkg/beam/core/graph/coder/coder.go
Original file line number Diff line number Diff line change
Expand Up @@ -188,7 +188,7 @@ const (
// It requires special handling in translation to the model pipeline in the latter case
// to add the incoming index for each input.
//
// TODO(Issue 18032): once this JIRA is done, this coder should become the new thing.
// TODO(https://github.com/apache/beam/issues/18032): once this JIRA is done, this coder should become the new thing.
CoGBK Kind = "CoGBK"
)

Expand Down Expand Up @@ -347,7 +347,7 @@ func NewT(c *Coder, w *WindowCoder) *Coder {
panic("window must not be nil")
}

// TODO(Issue 20510): Implement proper timer support.
// TODO(https://github.com/apache/beam/issues/20510): Implement proper timer support.
return &Coder{
Kind: Timer,
T: typex.New(reflect.TypeOf((*struct {
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/core/graph/coder/row.go
Original file line number Diff line number Diff line change
Expand Up @@ -186,7 +186,7 @@ func ReadRowHeader(r io.Reader) (int, []byte, error) {
// and can be skipped in decoding.
func IsFieldNil(nils []byte, f int) bool {
i, b := f/8, f%8
// Issue 21232: The row header can elide trailing 0 bytes,
// https://github.com/apache/beam/issues/21232: The row header can elide trailing 0 bytes,
// and we shouldn't care if there are trailing 0 bytes when doing a lookup.
return i < len(nils) && len(nils) != 0 && (nils[i]>>uint8(b))&0x1 == 1
}
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/core/graph/coder/row_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -864,7 +864,7 @@ func TestSchemaProviderInterface(t *testing.T) {
}

func TestRowHeader_TrailingZeroBytes(t *testing.T) {
// Issue 21232: The row header should elide trailing 0 bytes.
// https://github.com/apache/beam/issues/21232: The row header should elide trailing 0 bytes.
// But be tolerant of trailing 0 bytes.

const count = 255
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/core/graph/mtime/time.go
Original file line number Diff line number Diff line change
Expand Up @@ -37,7 +37,7 @@ const (

// EndOfGlobalWindowTime is the timestamp at the end of the global window. It
// is a day before the max timestamp.
// TODO(Issue 18951) Use GLOBAL_WINDOW_MAX_TIMESTAMP_MILLIS from the Runner API constants
// TODO(https://github.com/apache/beam/issues/18951) Use GLOBAL_WINDOW_MAX_TIMESTAMP_MILLIS from the Runner API constants
EndOfGlobalWindowTime = MaxTimestamp - 24*60*60*1000

// ZeroTimestamp is the default zero value time. It corresponds to the unix epoch.
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/core/runtime/exec/coder_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -188,7 +188,7 @@ func TestIterableCoder(t *testing.T) {
}
}

// TODO(Issue 20510): Update once proper timer support is added
// TODO(https://github.com/apache/beam/issues/20510): Update once proper timer support is added
func TestTimerCoder(t *testing.T) {
var buf bytes.Buffer
tCoder := coder.NewT(coder.NewVarInt(), coder.NewGlobalWindow())
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/core/runtime/exec/cogbk.go
Original file line number Diff line number Diff line change
Expand Up @@ -23,7 +23,7 @@ import (
"github.com/apache/beam/sdks/v2/go/pkg/beam/internal/errors"
)

// TODO(Issue 18032): This file contains support for the handling of CoGBK
// TODO(https://github.com/apache/beam/issues/18032): This file contains support for the handling of CoGBK
// over the model pipeline. Once it's a primitive, the translation will
// no longer be needed. See graphx/cogbk.go for details.

Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/core/runtime/exec/combine.go
Original file line number Diff line number Diff line change
Expand Up @@ -337,7 +337,7 @@ func (n *LiftedCombine) Up(ctx context.Context) error {
if err := n.Combine.Up(ctx); err != nil {
return err
}
// TODO(Issue 18944): replace with some better implementation
// TODO(https://github.com/apache/beam/issues/18944): replace with some better implementation
// once adding dependencies is easier.
// Arbitrary limit until a broader improvement can be demonstrated.
const cacheMax = 2000
Expand Down
4 changes: 2 additions & 2 deletions sdks/go/pkg/beam/core/runtime/exec/datasource.go
Original file line number Diff line number Diff line change
Expand Up @@ -134,7 +134,7 @@ func (n *DataSource) Process(ctx context.Context) error {
case coder.IsCoGBK(c):
cp = MakeElementDecoder(c.Components[0])

// TODO(Issue 18032): Support multiple value streams (coder components) with
// TODO(https://github.com/apache/beam/issues/18032): Support multiple value streams (coder components) with
// with CoGBK.
cvs = []ElementDecoder{MakeElementDecoder(c.Components[1])}
default:
Expand Down Expand Up @@ -472,7 +472,7 @@ func (n *DataSource) Split(splits []int64, frac float64, bufSize int64) (SplitRe
return SplitResult{PI: s, RI: s + 1}, nil
}

// TODO(Issue 20343) Eventually encode elements with the splittable
// TODO(https://github.com/apache/beam/issues/20343) Eventually encode elements with the splittable
// unit's input coder instead of the DataSource's coder.
encodeElms := n.makeEncodeElms()

Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/core/runtime/exec/dynsplit_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -110,7 +110,7 @@ func TestDynamicSplit(t *testing.T) {

// Validate split elements are encoded correctly by decoding them
// with the input coder to the path.
// TODO(Issue 20343) Switch to using splittable unit's input coder
// TODO(https://github.com/apache/beam/issues/20343) Switch to using splittable unit's input coder
// once that is implemented.
p, err := decodeDynSplitElm(splitRes.split.PS[0], cdr)
if err != nil {
Expand Down
4 changes: 2 additions & 2 deletions sdks/go/pkg/beam/core/runtime/exec/sdf.go
Original file line number Diff line number Diff line change
Expand Up @@ -313,7 +313,7 @@ func (n *TruncateSizedRestriction) ProcessElement(ctx context.Context, elm *Full
// For the main element, the way we fill it out depends on whether the input element
// is a KV or single-element. Single-elements might have been lifted out of
// their FullValue if they were decoded, so we need to have a case for that.
// TODO(Issue 20196): Optimize this so it's decided in exec/translate.go
// TODO(https://github.com/apache/beam/issues/20196): Optimize this so it's decided in exec/translate.go
// instead of checking per-element.
if e, ok := mainElm.Elm.(*FullValue); ok {
mainElm = e
Expand Down Expand Up @@ -487,7 +487,7 @@ func (n *ProcessSizedElementsAndRestrictions) ProcessElement(_ context.Context,
// is a KV or single-element. Single-elements might have been lifted out of
// their FullValue if they were decoded, so we need to have a case for that.
// Also, we use the the top-level windows and timestamp.
// TODO(Issue 20196): Optimize this so it's decided in exec/translate.go
// TODO(https://github.com/apache/beam/issues/20196): Optimize this so it's decided in exec/translate.go
// instead of checking per-element.
if userElm, ok := elm.Elm.(*FullValue).Elm.(*FullValue); ok {
mainIn.Key = FullValue{
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/core/runtime/exec/translate.go
Original file line number Diff line number Diff line change
Expand Up @@ -464,7 +464,7 @@ func (b *builder) makeLink(from string, id linkID) (Node, error) {

input := unmarshalKeyedValues(transform.GetInputs())
for i := 1; i < len(input); i++ {
// TODO(Issue 18602) Handle ViewFns for side inputs
// TODO(https://github.com/apache/beam/issues/18602) Handle ViewFns for side inputs

ec, wc, err := b.makeCoderForPCollection(input[i])
if err != nil {
Expand Down
8 changes: 4 additions & 4 deletions sdks/go/pkg/beam/core/runtime/graphx/coder.go
Original file line number Diff line number Diff line change
Expand Up @@ -73,7 +73,7 @@ func knownStandardCoders() []string {
urnIntervalWindow,
urnRowCoder,
urnNullableCoder,
// TODO(Issue 20510): Add urnTimerCoder once finalized.
// TODO(https://github.com/apache/beam/issues/20510): Add urnTimerCoder once finalized.
}
}

Expand Down Expand Up @@ -230,7 +230,7 @@ func (b *CoderUnmarshaller) makeCoder(id string, c *pipepb.Coder) (*coder.Coder,
kind = coder.CoGBK
root = typex.CoGBKType

// TODO(Issue 18032): If CoGBK with > 1 input, handle as special GBK. We expect
// TODO(https://github.com/apache/beam/issues/18032): If CoGBK with > 1 input, handle as special GBK. We expect
// it to be encoded as CoGBK<K,LP<CoGBKList<V,W,..>>>. Remove this handling once
// CoGBK has a first-class representation.

Expand Down Expand Up @@ -489,7 +489,7 @@ func (b *CoderMarshaller) Add(c *coder.Coder) (string, error) {
}
value := comp[1]
if len(comp) > 2 {
// TODO(Issue 18032): don't inject union coder for CoGBK.
// TODO(https://github.com/apache/beam/issues/18032): don't inject union coder for CoGBK.

union := b.internBuiltInCoder(urnCoGBKList, comp[1:]...)
value = b.internBuiltInCoder(urnLengthPrefixCoder, union)
Expand Down Expand Up @@ -537,7 +537,7 @@ func (b *CoderMarshaller) Add(c *coder.Coder) (string, error) {
}
return b.internRowCoder(s), nil

// TODO(Issue 20510): Handle coder.Timer support.
// TODO(https://github.com/apache/beam/issues/20510): Handle coder.Timer support.

default:
err := errors.Errorf("unexpected coder kind: %v", c.Kind)
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/core/runtime/graphx/cogbk.go
Original file line number Diff line number Diff line change
Expand Up @@ -26,7 +26,7 @@ import (

// CoGBK support
//
// TODO(Issue 18032): CoGBK is not a supported model primitive, so similarly to other
// TODO(https://github.com/apache/beam/issues/18032): CoGBK is not a supported model primitive, so similarly to other
// SDKs, a translation into GBK is performed to run on portable runners. Due to
// various constraints and to preserve CoGBK as a first-class concept in areas
// such as type-checking and for non-portability runners, the Go translation is
Expand Down
4 changes: 2 additions & 2 deletions sdks/go/pkg/beam/core/runtime/graphx/dataflow.go
Original file line number Diff line number Diff line change
Expand Up @@ -140,7 +140,7 @@ func EncodeCoderRef(c *coder.Coder) (*CoderRef, error) {

value := refs[1]
if len(c.Components) > 2 {
// TODO(Issue 18032): don't inject union coder for CoGBK.
// TODO(https://github.com/apache/beam/issues/18032): don't inject union coder for CoGBK.

union := &CoderRef{Type: cogbklistType, Components: refs[1:]}
value = &CoderRef{Type: lengthPrefixType, Components: []*CoderRef{union}}
Expand Down Expand Up @@ -252,7 +252,7 @@ func DecodeCoderRef(c *CoderRef) (*coder.Coder, error) {
kind = coder.CoGBK
root = typex.CoGBKType

// TODO(Issue 18032): If CoGBK with > 1 input, handle as special GBK. We expect
// TODO(https://github.com/apache/beam/issues/18032): If CoGBK with > 1 input, handle as special GBK. We expect
// it to be encoded as CoGBK<K,LP<Union<V,W,..>>. Remove this handling once
// CoGBK has a first-class representation.

Expand Down
6 changes: 3 additions & 3 deletions sdks/go/pkg/beam/core/runtime/graphx/translate.go
Original file line number Diff line number Diff line change
Expand Up @@ -91,8 +91,8 @@ func goCapabilities() []string {
URNMultiCore,
URNTruncate,
URNWorkerStatus,
URNMonitoringInfoShortID,
// TOOD(Issue 20287): Make this versioned.
URNMonitoringInfoShortID,
// TOOD(https://github.com/apache/beam/issues/20287): Make this versioned.
"beam:version:sdk_base:go",
}
return append(capabilities, knownStandardCoders()...)
Expand Down Expand Up @@ -595,7 +595,7 @@ func (m *marshaller) expandCrossLanguage(namedEdge NamedEdge) (string, error) {
}

func (m *marshaller) expandCoGBK(edge NamedEdge) (string, error) {
// TODO(Issue 18032): replace once CoGBK is a primitive. For now, we have to translate
// TODO(https://github.com/apache/beam/issues/18032): replace once CoGBK is a primitive. For now, we have to translate
// CoGBK with multiple PCollections as described in cogbk.go.
handleErr := func(err error) (string, error) {
return "", errors.Wrapf(err, "failed to expand CoGBK transform for edge: %v", edge)
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/core/runtime/harness/datamgr.go
Original file line number Diff line number Diff line change
Expand Up @@ -524,7 +524,7 @@ func (w *dataWriter) Close() error {
{
InstructionId: string(w.id.instID),
TransformId: w.id.ptransformID,
// TODO(Issue 21164): Set IsLast true on final flush instead of w/empty sentinel?
// TODO(https://github.com/apache/beam/issues/21164): Set IsLast true on final flush instead of w/empty sentinel?
// Empty data == sentinel
IsLast: true,
},
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/core/runtime/harness/monitoring.go
Original file line number Diff line number Diff line change
Expand Up @@ -194,7 +194,7 @@ func monitoring(p *exec.Plan, store *metrics.Store, supportShortID bool) ([]*pip
panic(err)
}

// TODO(Issue 20204): This metric should account for elements in multiple windows.
// TODO(https://github.com/apache/beam/issues/20204): This metric should account for elements in multiple windows.
payloads[getShortID(metrics.PCollectionLabels(pcol.ID), metricsx.UrnElementCount)] = payload

if !supportShortID {
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/core/util/jsonx/jsonx.go
Original file line number Diff line number Diff line change
Expand Up @@ -15,7 +15,7 @@

// Package jsonx contains utilities for working with JSON encoded data.
//
// TODO(Issue 20271): Delete this package once the SDK defaults to schemas.
// TODO(https://github.com/apache/beam/issues/20271): Delete this package once the SDK defaults to schemas.
package jsonx

import (
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/io/textio/textio.go
Original file line number Diff line number Diff line change
Expand Up @@ -109,7 +109,7 @@ func expandFn(ctx context.Context, glob string, emit func(string)) error {
}

// sizeFn pairs a filename with the size of that file in bytes.
// TODO(Issue 20607): Once CreateInitialRestriction supports Context params and
// TODO(https://github.com/apache/beam/issues/20607): Once CreateInitialRestriction supports Context params and
// error return values, this can be done in readSdfFn.CreateInitialRestriction.
func sizeFn(ctx context.Context, filename string) (string, int64, error) {
fs, err := filesystem.New(ctx, filename)
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/io/xlang/kafkaio/kafka.go
Original file line number Diff line number Diff line change
Expand Up @@ -41,7 +41,7 @@
// - Reference Class: org.apache.beam.sdk.io.kafka.KafkaIO
package kafkaio

// TODO(Issue 21000): Implement an API for specifying Kafka type serializers and
// TODO(https://github.com/apache/beam/issues/21000): Implement an API for specifying Kafka type serializers and
// deserializers.

import (
Expand Down
6 changes: 3 additions & 3 deletions sdks/go/pkg/beam/model/pipeline_v1/beam_runner_api.pb.go

Some generated files are not rendered by default. Learn more about how customized files appear on GitHub.

4 changes: 2 additions & 2 deletions sdks/go/pkg/beam/pardo.go
Original file line number Diff line number Diff line change
Expand Up @@ -65,8 +65,8 @@ func TryParDo(s Scope, dofn interface{}, col PCollection, opts ...Option) ([]PCo
return nil, fmt.Errorf("main input is global windowed in DoFn %v but side input %v is not, cannot map windows correctly. Consider re-windowing the side input PCollection before use", fn, i)
}
if (sideWfn.Kind == window.GlobalWindows) && !sideNode.Bounded() {
// TODO(Issue 21596): Replace this warning with an error return when proper streaming test functions have been added.
log.Warnf(context.Background(), "side input %v is global windowed in DoFn %v but is unbounded, DoFn will block until end of Global Window. Consider windowing your unbounded side input PCollection before use. This will cause your pipeline to fail in a future release, see Issue 21596 for details", i, fn)
// TODO(https://github.com/apache/beam/issues/21596): Replace this warning with an error return when proper streaming test functions have been added.
log.Warnf(context.Background(), "side input %v is global windowed in DoFn %v but is unbounded, DoFn will block until end of Global Window. Consider windowing your unbounded side input PCollection before use. This will cause your pipeline to fail in a future release, see https://github.com/apache/beam/issues/21596 for details", i, fn)
}
in = append(in, s.Input.n)
}
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/pardo_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -146,7 +146,7 @@ func TestParDoSideInputValidation(t *testing.T) {
wFn *window.Fn
isBounded bool
}{
// TODO(Issue 21596): Re-enable this test case once proper streaming testing support is finished.
// TODO(https://github.com/apache/beam/issues/21596): Re-enable this test case once proper streaming testing support is finished.
// {
// "global window unbounded",
// window.NewGlobalWindows(),
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/runners/dataflow/dataflow.go
Original file line number Diff line number Diff line change
Expand Up @@ -76,7 +76,7 @@ var (
workerZone = flag.String("worker_zone", "", "Dataflow worker zone (optional)")
dataflowServiceOptions = flag.String("dataflow_service_options", "", "Comma separated list of additional job modes and configurations (optional)")
flexRSGoal = flag.String("flexrs_goal", "", "Which Flexible Resource Scheduling mode to run in (optional)")
// TODO(Issue 21604) Turn this on once TO_STRING is implemented
// TODO(https://github.com/apache/beam/issues/21604) Turn this on once TO_STRING is implemented
// enableHotKeyLogging = flag.Bool("enable_hot_key_logging", false, "Specifies that when a hot key is detected in the pipeline, the literal, human-readable key is printed in the user's Cloud Logging project (optional).")

// Streaming update flags
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/runners/universal/runnerlib/stage.go
Original file line number Diff line number Diff line change
Expand Up @@ -83,7 +83,7 @@ func StageViaPortableApi(ctx context.Context, cc *grpc.ClientConn, binary, st st

case *jobpb.ArtifactRequestWrapper_GetArtifact:
switch typeUrn := request.GetArtifact.Artifact.TypeUrn; typeUrn {
// TODO(Issue 21459): Legacy Type URN. If requested, provide the binary.
// TODO(https://github.com/apache/beam/issues/21459): Legacy Type URN. If requested, provide the binary.
// To be removed later in 2022, once thoroughly obsolete.
case graphx.URNArtifactGoWorker:
if err := StageFile(binary, stream); err != nil {
Expand Down
4 changes: 2 additions & 2 deletions sdks/go/pkg/beam/runners/vet/vet.go
Original file line number Diff line number Diff line change
Expand Up @@ -21,7 +21,7 @@
// can use this as a sanity check on whether a given pipeline avoids known
// performance bottlenecks.
//
// TODO(Issue 19402): Add usage documentation.
// TODO(https://github.com/apache/beam/issues/19402): Add usage documentation.
package vet

import (
Expand Down Expand Up @@ -503,7 +503,7 @@ func (e *Eval) Bytes() []byte {
// is used.
func (e *Eval) extractGraphFn(fn *graph.Fn) {
if fn.DynFn != nil {
// TODO(Issue 19401) handle dynamics if necessary (probably not since it's got general function handling)
// TODO(https://github.com/apache/beam/issues/19401) handle dynamics if necessary (probably not since it's got general function handling)
e.diag(" dynamic function")
return
}
Expand Down
2 changes: 1 addition & 1 deletion sdks/go/pkg/beam/transforms/stats/quantiles_test.go
Original file line number Diff line number Diff line change
Expand Up @@ -30,7 +30,7 @@ func init() {
beam.RegisterFunction(weightedElementToKv)

// In practice, this runs faster than plain reflection.
// TODO(Issue 20271): Remove once collisions don't occur for starcgen over test code and an equivalent is generated for us.
// TODO(https://github.com/apache/beam/issues/20271): Remove once collisions don't occur for starcgen over test code and an equivalent is generated for us.
reflectx.RegisterFunc(reflect.ValueOf(less).Type(), func(_ interface{}) reflectx.Func {
return newIntLess()
})
Expand Down
Loading

0 comments on commit ab256c5

Please sign in to comment.