You are viewing a plain text version of this content. The canonical link for it is here.
Posted to github@beam.apache.org by GitBox <gi...@apache.org> on 2022/06/23 15:07:12 UTC

[GitHub] [beam] jrmccluskey opened a new pull request, #22019: Remove unused legacy dataflow translate code

jrmccluskey opened a new pull request, #22019:
URL: https://github.com/apache/beam/pull/22019

   Current Dataflow job submission routing always enables portable job submission, making legacy Dataflow Step translation unused code. This change removes that routing and the dead code as part of the code health improvement efforts outlined in #21388. 
   
   ------------------------
   
   Thank you for your contribution! Follow this checklist to help us incorporate your contribution quickly and easily:
   
    - [ ] [**Choose reviewer(s)**](https://beam.apache.org/contribute/#make-your-change) and mention them in a comment (`R: @username`).
    - [ ] Mention the appropriate issue in your description (for example: `addresses #123`), if applicable. This will automatically add a link to the pull request in the issue. If you would like the issue to automatically close on merging the pull request, comment `fixes #<ISSUE NUMBER>` instead.
    - [ ] Update `CHANGES.md` with noteworthy changes.
    - [ ] If this contribution is large, please file an Apache [Individual Contributor License Agreement](https://www.apache.org/licenses/icla.pdf).
   
   See the [Contributor Guide](https://beam.apache.org/contribute) for more tips on [how to make review process smoother](https://beam.apache.org/contribute/#make-reviewers-job-easier).
   
   To check the build health, please visit [https://github.com/apache/beam/blob/master/.test-infra/BUILD_STATUS.md](https://github.com/apache/beam/blob/master/.test-infra/BUILD_STATUS.md)
   
   GitHub Actions Tests Status (on master branch)
   ------------------------------------------------------------------------------------------------
   [![Build python source distribution and wheels](https://github.com/apache/beam/workflows/Build%20python%20source%20distribution%20and%20wheels/badge.svg?branch=master&event=schedule)](https://github.com/apache/beam/actions?query=workflow%3A%22Build+python+source+distribution+and+wheels%22+branch%3Amaster+event%3Aschedule)
   [![Python tests](https://github.com/apache/beam/workflows/Python%20tests/badge.svg?branch=master&event=schedule)](https://github.com/apache/beam/actions?query=workflow%3A%22Python+Tests%22+branch%3Amaster+event%3Aschedule)
   [![Java tests](https://github.com/apache/beam/workflows/Java%20Tests/badge.svg?branch=master&event=schedule)](https://github.com/apache/beam/actions?query=workflow%3A%22Java+Tests%22+branch%3Amaster+event%3Aschedule)
   
   See [CI.md](https://github.com/apache/beam/blob/master/CI.md) for more information about GitHub Actions CI.
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] asf-ci commented on pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
asf-ci commented on PR #22019:
URL: https://github.com/apache/beam/pull/22019#issuecomment-1164530583

   Can one of the admins verify this patch?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] jrmccluskey commented on pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
jrmccluskey commented on PR #22019:
URL: https://github.com/apache/beam/pull/22019#issuecomment-1164533834

   Run Go PostCommit


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] asf-ci commented on pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
asf-ci commented on PR #22019:
URL: https://github.com/apache/beam/pull/22019#issuecomment-1164530593

   Can one of the admins verify this patch?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] lostluck commented on a diff in pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
lostluck commented on code in PR #22019:
URL: https://github.com/apache/beam/pull/22019#discussion_r909131113


##########
sdks/go/pkg/beam/runners/dataflow/dataflowlib/translate.go:
##########
@@ -1,363 +0,0 @@
-// Licensed to the Apache Software Foundation (ASF) under one or more
-// contributor license agreements.  See the NOTICE file distributed with
-// this work for additional information regarding copyright ownership.
-// The ASF licenses this file to You under the Apache License, Version 2.0
-// (the "License"); you may not use this file except in compliance with
-// the License.  You may obtain a copy of the License at
-//
-//    http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing, software
-// distributed under the License is distributed on an "AS IS" BASIS,
-// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-// See the License for the specific language governing permissions and
-// limitations under the License.
-
-package dataflowlib
-
-import (
-	"bytes"
-	"encoding/json"
-	"fmt"
-	"net/url"
-	"path"
-
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/graph/coder"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/graph/mtime"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/graph/window"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/runtime/exec"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/runtime/graphx"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/runtime/pipelinex"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/typex"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/util/protox"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/util/reflectx"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/util/stringx"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/internal/errors"
-	pipepb "github.com/apache/beam/sdks/v2/go/pkg/beam/model/pipeline_v1"
-	"github.com/golang/protobuf/proto"
-	df "google.golang.org/api/dataflow/v1b3"
-)
-
-const (
-	impulseKind    = "CreateCollection"
-	parDoKind      = "ParallelDo"
-	combineKind    = "CombineValues"
-	flattenKind    = "Flatten"
-	gbkKind        = "GroupByKey"
-	windowIntoKind = "Bucket"
-
-	sideInputKind = "CollectionToSingleton"
-)
-
-// translate translates a pipeline into a sequence of Dataflow steps. The step
-// representation and its semantics are complex. In particular, the service
-// optimizes the steps (step fusing, etc.) and may move steps around. Our
-// decorations of the steps must thus be robust against such changes, so that
-// they can be properly decoded in the harness. There are multiple quirks and
-// requirements of specific semi-opaque formats, such as base64 encoded blobs.
-//
-// Moreover, the harness sees pieces of the translated steps only -- not the
-// full graph. Special steps are also inserted around GBK, for example, which
-// makes the placement of the decoration somewhat tricky. The harness will
-// also never see steps that the service executes directly, notably GBK/CoGBK.
-func translate(p *pipepb.Pipeline) ([]*df.Step, error) {
-	// NOTE: Dataflow apparently assumes that the steps are in topological order.
-	// Otherwise, it fails with "Output out for step  was not found.". We assume
-	// the pipeline has been normalized and each subtransform list is in such order.
-
-	x := newTranslator(p.GetComponents())
-	return x.translateTransforms("", p.GetRootTransformIds())
-}
-
-type translator struct {
-	comp          *pipepb.Components
-	pcollections  map[string]*outputReference
-	coders        *graphx.CoderUnmarshaller
-	bogusCoderRef *graphx.CoderRef
-}
-
-func newTranslator(comp *pipepb.Components) *translator {
-	bytesCoderRef, _ := graphx.EncodeCoderRef(coder.NewW(coder.NewBytes(), coder.NewGlobalWindow()))

Review Comment:
   There's a few things in the `graphx` package that should be removable since it's only used from here. Specifically the "coderref" and "dataflow" handling code in graphx.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] lostluck commented on a diff in pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
lostluck commented on code in PR #22019:
URL: https://github.com/apache/beam/pull/22019#discussion_r911180602


##########
sdks/go/pkg/beam/runners/dataflow/dataflowlib/translate.go:
##########
@@ -1,363 +0,0 @@
-// Licensed to the Apache Software Foundation (ASF) under one or more
-// contributor license agreements.  See the NOTICE file distributed with
-// this work for additional information regarding copyright ownership.
-// The ASF licenses this file to You under the Apache License, Version 2.0
-// (the "License"); you may not use this file except in compliance with
-// the License.  You may obtain a copy of the License at
-//
-//    http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing, software
-// distributed under the License is distributed on an "AS IS" BASIS,
-// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-// See the License for the specific language governing permissions and
-// limitations under the License.
-
-package dataflowlib
-
-import (
-	"bytes"
-	"encoding/json"
-	"fmt"
-	"net/url"
-	"path"
-
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/graph/coder"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/graph/mtime"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/graph/window"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/runtime/exec"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/runtime/graphx"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/runtime/pipelinex"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/typex"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/util/protox"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/util/reflectx"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/util/stringx"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/internal/errors"
-	pipepb "github.com/apache/beam/sdks/v2/go/pkg/beam/model/pipeline_v1"
-	"github.com/golang/protobuf/proto"
-	df "google.golang.org/api/dataflow/v1b3"
-)
-
-const (
-	impulseKind    = "CreateCollection"
-	parDoKind      = "ParallelDo"
-	combineKind    = "CombineValues"
-	flattenKind    = "Flatten"
-	gbkKind        = "GroupByKey"
-	windowIntoKind = "Bucket"
-
-	sideInputKind = "CollectionToSingleton"
-)
-
-// translate translates a pipeline into a sequence of Dataflow steps. The step
-// representation and its semantics are complex. In particular, the service
-// optimizes the steps (step fusing, etc.) and may move steps around. Our
-// decorations of the steps must thus be robust against such changes, so that
-// they can be properly decoded in the harness. There are multiple quirks and
-// requirements of specific semi-opaque formats, such as base64 encoded blobs.
-//
-// Moreover, the harness sees pieces of the translated steps only -- not the
-// full graph. Special steps are also inserted around GBK, for example, which
-// makes the placement of the decoration somewhat tricky. The harness will
-// also never see steps that the service executes directly, notably GBK/CoGBK.
-func translate(p *pipepb.Pipeline) ([]*df.Step, error) {
-	// NOTE: Dataflow apparently assumes that the steps are in topological order.
-	// Otherwise, it fails with "Output out for step  was not found.". We assume
-	// the pipeline has been normalized and each subtransform list is in such order.
-
-	x := newTranslator(p.GetComponents())
-	return x.translateTransforms("", p.GetRootTransformIds())
-}
-
-type translator struct {
-	comp          *pipepb.Components
-	pcollections  map[string]*outputReference
-	coders        *graphx.CoderUnmarshaller
-	bogusCoderRef *graphx.CoderRef
-}
-
-func newTranslator(comp *pipepb.Components) *translator {
-	bytesCoderRef, _ := graphx.EncodeCoderRef(coder.NewW(coder.NewBytes(), coder.NewGlobalWindow()))

Review Comment:
   I'm pretty sure it's dead, but I agree that should be deferred to another PR.



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] lostluck merged pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
lostluck merged PR #22019:
URL: https://github.com/apache/beam/pull/22019


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] asf-ci commented on pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
asf-ci commented on PR #22019:
URL: https://github.com/apache/beam/pull/22019#issuecomment-1164530596

   Can one of the admins verify this patch?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] github-actions[bot] commented on pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
github-actions[bot] commented on PR #22019:
URL: https://github.com/apache/beam/pull/22019#issuecomment-1164585105

   Assigning reviewers. If you would like to opt out of this review, comment `assign to next reviewer`:
   
   R: @lostluck for label go.
   
   Available commands:
   - `stop reviewer notifications` - opt out of the automated review tooling
   - `remind me after tests pass` - tag the comment author after tests pass
   - `waiting on author` - shift the attention set back to the author (any comment or push by the author will return the attention set to the reviewers)
   
   The PR bot will only process comments in the main thread (not review comments).


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] asf-ci commented on pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
asf-ci commented on PR #22019:
URL: https://github.com/apache/beam/pull/22019#issuecomment-1164530590

   Can one of the admins verify this patch?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] codecov[bot] commented on pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
codecov[bot] commented on PR #22019:
URL: https://github.com/apache/beam/pull/22019#issuecomment-1164562774

   # [Codecov](https://codecov.io/gh/apache/beam/pull/22019?src=pr&el=h1&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) Report
   > Merging [#22019](https://codecov.io/gh/apache/beam/pull/22019?src=pr&el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (a70613c) into [master](https://codecov.io/gh/apache/beam/commit/78ec29eb903177524903a5b0792817b169a0f9ca?el=desc&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) (78ec29e) will **increase** coverage by `0.20%`.
   > The diff coverage is `0.00%`.
   
   ```diff
   @@            Coverage Diff             @@
   ##           master   #22019      +/-   ##
   ==========================================
   + Coverage   73.99%   74.20%   +0.20%     
   ==========================================
     Files         703      702       -1     
     Lines       92936    92680     -256     
   ==========================================
     Hits        68769    68769              
   + Misses      22901    22645     -256     
     Partials     1266     1266              
   ```
   
   | Flag | Coverage Δ | |
   |---|---|---|
   | go | `51.44% <0.00%> (+0.48%)` | :arrow_up: |
   
   Flags with carried forward coverage won't be shown. [Click here](https://docs.codecov.io/docs/carryforward-flags?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#carryforward-flags-in-the-pull-request-comment) to find out more.
   
   | [Impacted Files](https://codecov.io/gh/apache/beam/pull/22019?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation) | Coverage Δ | |
   |---|---|---|
   | [...ks/go/pkg/beam/runners/dataflow/dataflowlib/job.go](https://codecov.io/gh/apache/beam/pull/22019/diff?src=pr&el=tree&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation#diff-c2Rrcy9nby9wa2cvYmVhbS9ydW5uZXJzL2RhdGFmbG93L2RhdGFmbG93bGliL2pvYi5nbw==) | `22.67% <0.00%> (+1.12%)` | :arrow_up: |
   
   ------
   
   [Continue to review full report at Codecov](https://codecov.io/gh/apache/beam/pull/22019?src=pr&el=continue&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   > **Legend** - [Click here to learn more](https://docs.codecov.io/docs/codecov-delta?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation)
   > `Δ = absolute <relative> (impact)`, `ø = not affected`, `? = missing data`
   > Powered by [Codecov](https://codecov.io/gh/apache/beam/pull/22019?src=pr&el=footer&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Last update [78ec29e...a70613c](https://codecov.io/gh/apache/beam/pull/22019?src=pr&el=lastupdated&utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation). Read the [comment docs](https://docs.codecov.io/docs/pull-request-comments?utm_medium=referral&utm_source=github&utm_content=comment&utm_campaign=pr+comments&utm_term=The+Apache+Software+Foundation).
   


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] lostluck commented on pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
lostluck commented on PR #22019:
URL: https://github.com/apache/beam/pull/22019#issuecomment-1165098924

   Run Go Postcommit


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] asf-ci commented on pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
asf-ci commented on PR #22019:
URL: https://github.com/apache/beam/pull/22019#issuecomment-1164530586

   Can one of the admins verify this patch?


-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org


[GitHub] [beam] jrmccluskey commented on a diff in pull request #22019: Remove unused legacy dataflow translate code

Posted by GitBox <gi...@apache.org>.
jrmccluskey commented on code in PR #22019:
URL: https://github.com/apache/beam/pull/22019#discussion_r909680643


##########
sdks/go/pkg/beam/runners/dataflow/dataflowlib/translate.go:
##########
@@ -1,363 +0,0 @@
-// Licensed to the Apache Software Foundation (ASF) under one or more
-// contributor license agreements.  See the NOTICE file distributed with
-// this work for additional information regarding copyright ownership.
-// The ASF licenses this file to You under the Apache License, Version 2.0
-// (the "License"); you may not use this file except in compliance with
-// the License.  You may obtain a copy of the License at
-//
-//    http://www.apache.org/licenses/LICENSE-2.0
-//
-// Unless required by applicable law or agreed to in writing, software
-// distributed under the License is distributed on an "AS IS" BASIS,
-// WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
-// See the License for the specific language governing permissions and
-// limitations under the License.
-
-package dataflowlib
-
-import (
-	"bytes"
-	"encoding/json"
-	"fmt"
-	"net/url"
-	"path"
-
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/graph/coder"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/graph/mtime"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/graph/window"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/runtime/exec"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/runtime/graphx"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/runtime/pipelinex"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/typex"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/util/protox"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/util/reflectx"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/core/util/stringx"
-	"github.com/apache/beam/sdks/v2/go/pkg/beam/internal/errors"
-	pipepb "github.com/apache/beam/sdks/v2/go/pkg/beam/model/pipeline_v1"
-	"github.com/golang/protobuf/proto"
-	df "google.golang.org/api/dataflow/v1b3"
-)
-
-const (
-	impulseKind    = "CreateCollection"
-	parDoKind      = "ParallelDo"
-	combineKind    = "CombineValues"
-	flattenKind    = "Flatten"
-	gbkKind        = "GroupByKey"
-	windowIntoKind = "Bucket"
-
-	sideInputKind = "CollectionToSingleton"
-)
-
-// translate translates a pipeline into a sequence of Dataflow steps. The step
-// representation and its semantics are complex. In particular, the service
-// optimizes the steps (step fusing, etc.) and may move steps around. Our
-// decorations of the steps must thus be robust against such changes, so that
-// they can be properly decoded in the harness. There are multiple quirks and
-// requirements of specific semi-opaque formats, such as base64 encoded blobs.
-//
-// Moreover, the harness sees pieces of the translated steps only -- not the
-// full graph. Special steps are also inserted around GBK, for example, which
-// makes the placement of the decoration somewhat tricky. The harness will
-// also never see steps that the service executes directly, notably GBK/CoGBK.
-func translate(p *pipepb.Pipeline) ([]*df.Step, error) {
-	// NOTE: Dataflow apparently assumes that the steps are in topological order.
-	// Otherwise, it fails with "Output out for step  was not found.". We assume
-	// the pipeline has been normalized and each subtransform list is in such order.
-
-	x := newTranslator(p.GetComponents())
-	return x.translateTransforms("", p.GetRootTransformIds())
-}
-
-type translator struct {
-	comp          *pipepb.Components
-	pcollections  map[string]*outputReference
-	coders        *graphx.CoderUnmarshaller
-	bogusCoderRef *graphx.CoderRef
-}
-
-func newTranslator(comp *pipepb.Components) *translator {
-	bytesCoderRef, _ := graphx.EncodeCoderRef(coder.NewW(coder.NewBytes(), coder.NewGlobalWindow()))

Review Comment:
   The CoderRef stuff seems to still be used in graphx/user.go and beam/encoding.go, I'm not sure that's dead code



-- 
This is an automated message from the Apache Git Service.
To respond to the message, please log on to GitHub and use the
URL above to go to the specific comment.

To unsubscribe, e-mail: github-unsubscribe@beam.apache.org

For queries about this service, please contact Infrastructure at:
users@infra.apache.org