You are viewing a plain text version of this content. The canonical link for it is here.
Posted to commits@beam.apache.org by ke...@apache.org on 2017/10/12 01:40:58 UTC

[2/4] beam git commit: [BEAM-2576] Reflect portability proto changes in Go

[BEAM-2576] Reflect portability proto changes in Go


Project: http://git-wip-us.apache.org/repos/asf/beam/repo
Commit: http://git-wip-us.apache.org/repos/asf/beam/commit/5fba6326
Tree: http://git-wip-us.apache.org/repos/asf/beam/tree/5fba6326
Diff: http://git-wip-us.apache.org/repos/asf/beam/diff/5fba6326

Branch: refs/heads/master
Commit: 5fba6326ecf49a197b1fb0f4402f05cdd64dc124
Parents: 6dd90d8
Author: Henning Rohde <he...@google.com>
Authored: Wed Oct 11 17:44:50 2017 -0700
Committer: Henning Rohde <he...@google.com>
Committed: Wed Oct 11 17:45:05 2017 -0700

----------------------------------------------------------------------
 .../src/main/proto/beam_fn_api.proto            |   1 +
 .../src/main/proto/beam_provision_api.proto     |   1 +
 .../src/main/proto/beam_artifact_api.proto      |   1 +
 .../src/main/proto/beam_job_api.proto           |   1 +
 .../src/main/proto/beam_runner_api.proto        |   1 +
 model/pipeline/src/main/proto/endpoints.proto   |   1 +
 .../src/main/proto/standard_window_fns.proto    |   1 +
 runners/gcp/gcemd/main.go                       |   2 +-
 runners/gcp/gcsproxy/main.go                    |   2 +-
 sdks/go/cmd/beamctl/cmd/artifact.go             |   2 +-
 sdks/go/pkg/beam/artifact/gcsproxy/retrieval.go |   2 +-
 sdks/go/pkg/beam/artifact/gcsproxy/staging.go   |   2 +-
 sdks/go/pkg/beam/artifact/materialize.go        |   2 +-
 sdks/go/pkg/beam/artifact/materialize_test.go   |   2 +-
 sdks/go/pkg/beam/artifact/server_test.go        |   2 +-
 sdks/go/pkg/beam/artifact/stage.go              |   2 +-
 sdks/go/pkg/beam/artifact/stage_test.go         |   2 +-
 .../fnexecution_v1/beam_provision_api.pb.go     | 206 ++++++
 sdks/go/pkg/beam/model/gen.go                   |   4 +-
 .../jobmanagement_v1/beam_artifact_api.pb.go    | 715 ++++++++++++++++++
 .../beam_provision_api.pb.go                    | 219 ------
 .../beam_artifact_api.pb.go                     | 729 -------------------
 sdks/go/pkg/beam/provision/provison.go          |   2 +-
 23 files changed, 941 insertions(+), 961 deletions(-)
----------------------------------------------------------------------


http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/model/fn-execution/src/main/proto/beam_fn_api.proto
----------------------------------------------------------------------
diff --git a/model/fn-execution/src/main/proto/beam_fn_api.proto b/model/fn-execution/src/main/proto/beam_fn_api.proto
index 18c26ef..7d3e05b 100644
--- a/model/fn-execution/src/main/proto/beam_fn_api.proto
+++ b/model/fn-execution/src/main/proto/beam_fn_api.proto
@@ -34,6 +34,7 @@ syntax = "proto3";
 
 package org.apache.beam.model.fn_execution.v1;
 
+option go_package = "fnexecution_v1";
 option java_package = "org.apache.beam.model.fnexecution.v1";
 option java_outer_classname = "BeamFnApi";
 

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/model/fn-execution/src/main/proto/beam_provision_api.proto
----------------------------------------------------------------------
diff --git a/model/fn-execution/src/main/proto/beam_provision_api.proto b/model/fn-execution/src/main/proto/beam_provision_api.proto
index ed5c78a..d203c85 100644
--- a/model/fn-execution/src/main/proto/beam_provision_api.proto
+++ b/model/fn-execution/src/main/proto/beam_provision_api.proto
@@ -25,6 +25,7 @@ syntax = "proto3";
 
 package org.apache.beam.model.fn_execution.v1;
 
+option go_package = "fnexecution_v1";
 option java_package = "org.apache.beam.model.fnexecution.v1";
 option java_outer_classname = "ProvisionApi";
 

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/model/job-management/src/main/proto/beam_artifact_api.proto
----------------------------------------------------------------------
diff --git a/model/job-management/src/main/proto/beam_artifact_api.proto b/model/job-management/src/main/proto/beam_artifact_api.proto
index 4b3ac0d..387e63f 100644
--- a/model/job-management/src/main/proto/beam_artifact_api.proto
+++ b/model/job-management/src/main/proto/beam_artifact_api.proto
@@ -25,6 +25,7 @@ syntax = "proto3";
 
 package org.apache.beam.model.job_management.v1;
 
+option go_package = "jobmanagement_v1";
 option java_package = "org.apache.beam.model.jobmanagement.v1";
 option java_outer_classname = "ArtifactApi";
 

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/model/job-management/src/main/proto/beam_job_api.proto
----------------------------------------------------------------------
diff --git a/model/job-management/src/main/proto/beam_job_api.proto b/model/job-management/src/main/proto/beam_job_api.proto
index 6465383..a045ad3 100644
--- a/model/job-management/src/main/proto/beam_job_api.proto
+++ b/model/job-management/src/main/proto/beam_job_api.proto
@@ -25,6 +25,7 @@ syntax = "proto3";
 
 package org.apache.beam.model.job_management.v1;
 
+option go_package = "jobmanagement_v1";
 option java_package = "org.apache.beam.model.jobmanagement.v1";
 option java_outer_classname = "JobApi";
 

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/model/pipeline/src/main/proto/beam_runner_api.proto
----------------------------------------------------------------------
diff --git a/model/pipeline/src/main/proto/beam_runner_api.proto b/model/pipeline/src/main/proto/beam_runner_api.proto
index 36369dd..b45be09 100644
--- a/model/pipeline/src/main/proto/beam_runner_api.proto
+++ b/model/pipeline/src/main/proto/beam_runner_api.proto
@@ -25,6 +25,7 @@ syntax = "proto3";
 
 package org.apache.beam.model.pipeline.v1;
 
+option go_package = "pipeline_v1";
 option java_package = "org.apache.beam.model.pipeline.v1";
 option java_outer_classname = "RunnerApi";
 

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/model/pipeline/src/main/proto/endpoints.proto
----------------------------------------------------------------------
diff --git a/model/pipeline/src/main/proto/endpoints.proto b/model/pipeline/src/main/proto/endpoints.proto
index 0ed398e..d807140 100644
--- a/model/pipeline/src/main/proto/endpoints.proto
+++ b/model/pipeline/src/main/proto/endpoints.proto
@@ -24,6 +24,7 @@ syntax = "proto3";
 
 package org.apache.beam.model.pipeline.v1;
 
+option go_package = "pipeline_v1";
 option java_package = "org.apache.beam.model.pipeline.v1";
 option java_outer_classname = "Endpoints";
 

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/model/pipeline/src/main/proto/standard_window_fns.proto
----------------------------------------------------------------------
diff --git a/model/pipeline/src/main/proto/standard_window_fns.proto b/model/pipeline/src/main/proto/standard_window_fns.proto
index 4bccc6f..db26d91 100644
--- a/model/pipeline/src/main/proto/standard_window_fns.proto
+++ b/model/pipeline/src/main/proto/standard_window_fns.proto
@@ -25,6 +25,7 @@ syntax = "proto3";
 
 package org.apache.beam.model.pipeline.v1;
 
+option go_package = "pipeline_v1";
 option java_package = "org.apache.beam.model.pipeline.v1";
 option java_outer_classname = "StandardWindowFns";
 

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/runners/gcp/gcemd/main.go
----------------------------------------------------------------------
diff --git a/runners/gcp/gcemd/main.go b/runners/gcp/gcemd/main.go
index 66b049e..6c12907 100644
--- a/runners/gcp/gcemd/main.go
+++ b/runners/gcp/gcemd/main.go
@@ -22,7 +22,7 @@ import (
 	"net"
 
 	"cloud.google.com/go/compute/metadata"
-	pb "github.com/apache/beam/sdks/go/pkg/beam/model/org_apache_beam_fn_v1"
+	pb "github.com/apache/beam/sdks/go/pkg/beam/model/fnexecution_v1"
 	"github.com/apache/beam/sdks/go/pkg/beam/provision"
 	"golang.org/x/net/context"
 	"google.golang.org/grpc"

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/runners/gcp/gcsproxy/main.go
----------------------------------------------------------------------
diff --git a/runners/gcp/gcsproxy/main.go b/runners/gcp/gcsproxy/main.go
index ec63032..4123b6b 100644
--- a/runners/gcp/gcsproxy/main.go
+++ b/runners/gcp/gcsproxy/main.go
@@ -24,7 +24,7 @@ import (
 	"net"
 
 	"github.com/apache/beam/sdks/go/pkg/beam/artifact/gcsproxy"
-	pb "github.com/apache/beam/sdks/go/pkg/beam/model/org_apache_beam_runner_v1"
+	pb "github.com/apache/beam/sdks/go/pkg/beam/model/jobmanagement_v1"
 	"google.golang.org/grpc"
 )
 

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/sdks/go/cmd/beamctl/cmd/artifact.go
----------------------------------------------------------------------
diff --git a/sdks/go/cmd/beamctl/cmd/artifact.go b/sdks/go/cmd/beamctl/cmd/artifact.go
index 9898282..eaaaa9a 100644
--- a/sdks/go/cmd/beamctl/cmd/artifact.go
+++ b/sdks/go/cmd/beamctl/cmd/artifact.go
@@ -19,7 +19,7 @@ import (
 	"path/filepath"
 
 	"github.com/apache/beam/sdks/go/pkg/beam/artifact"
-	pb "github.com/apache/beam/sdks/go/pkg/beam/model/org_apache_beam_runner_v1"
+	pb "github.com/apache/beam/sdks/go/pkg/beam/model/jobmanagement_v1"
 	"github.com/spf13/cobra"
 )
 

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/sdks/go/pkg/beam/artifact/gcsproxy/retrieval.go
----------------------------------------------------------------------
diff --git a/sdks/go/pkg/beam/artifact/gcsproxy/retrieval.go b/sdks/go/pkg/beam/artifact/gcsproxy/retrieval.go
index 7a11568..dede7a5 100644
--- a/sdks/go/pkg/beam/artifact/gcsproxy/retrieval.go
+++ b/sdks/go/pkg/beam/artifact/gcsproxy/retrieval.go
@@ -19,7 +19,7 @@ import (
 	"fmt"
 	"io"
 
-	pb "github.com/apache/beam/sdks/go/pkg/beam/model/org_apache_beam_runner_v1"
+	pb "github.com/apache/beam/sdks/go/pkg/beam/model/jobmanagement_v1"
 	"github.com/apache/beam/sdks/go/pkg/beam/util/gcsx"
 	"github.com/golang/protobuf/proto"
 	"golang.org/x/net/context"

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/sdks/go/pkg/beam/artifact/gcsproxy/staging.go
----------------------------------------------------------------------
diff --git a/sdks/go/pkg/beam/artifact/gcsproxy/staging.go b/sdks/go/pkg/beam/artifact/gcsproxy/staging.go
index c751d36..6e62bb9 100644
--- a/sdks/go/pkg/beam/artifact/gcsproxy/staging.go
+++ b/sdks/go/pkg/beam/artifact/gcsproxy/staging.go
@@ -26,7 +26,7 @@ import (
 	"path"
 	"sync"
 
-	pb "github.com/apache/beam/sdks/go/pkg/beam/model/org_apache_beam_runner_v1"
+	pb "github.com/apache/beam/sdks/go/pkg/beam/model/jobmanagement_v1"
 	"github.com/apache/beam/sdks/go/pkg/beam/util/gcsx"
 	"github.com/golang/protobuf/proto"
 	"golang.org/x/net/context"

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/sdks/go/pkg/beam/artifact/materialize.go
----------------------------------------------------------------------
diff --git a/sdks/go/pkg/beam/artifact/materialize.go b/sdks/go/pkg/beam/artifact/materialize.go
index 93bed65..fb93669 100644
--- a/sdks/go/pkg/beam/artifact/materialize.go
+++ b/sdks/go/pkg/beam/artifact/materialize.go
@@ -30,7 +30,7 @@ import (
 	"sync"
 	"time"
 
-	pb "github.com/apache/beam/sdks/go/pkg/beam/model/org_apache_beam_runner_v1"
+	pb "github.com/apache/beam/sdks/go/pkg/beam/model/jobmanagement_v1"
 	"github.com/apache/beam/sdks/go/pkg/beam/util/errorx"
 	"github.com/apache/beam/sdks/go/pkg/beam/util/grpcx"
 )

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/sdks/go/pkg/beam/artifact/materialize_test.go
----------------------------------------------------------------------
diff --git a/sdks/go/pkg/beam/artifact/materialize_test.go b/sdks/go/pkg/beam/artifact/materialize_test.go
index 37f6c22..144d803 100644
--- a/sdks/go/pkg/beam/artifact/materialize_test.go
+++ b/sdks/go/pkg/beam/artifact/materialize_test.go
@@ -24,7 +24,7 @@ import (
 	"path/filepath"
 	"testing"
 
-	pb "github.com/apache/beam/sdks/go/pkg/beam/model/org_apache_beam_runner_v1"
+	pb "github.com/apache/beam/sdks/go/pkg/beam/model/jobmanagement_v1"
 	"github.com/apache/beam/sdks/go/pkg/beam/util/grpcx"
 	"google.golang.org/grpc"
 )

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/sdks/go/pkg/beam/artifact/server_test.go
----------------------------------------------------------------------
diff --git a/sdks/go/pkg/beam/artifact/server_test.go b/sdks/go/pkg/beam/artifact/server_test.go
index da17544..bb1c06c 100644
--- a/sdks/go/pkg/beam/artifact/server_test.go
+++ b/sdks/go/pkg/beam/artifact/server_test.go
@@ -22,7 +22,7 @@ import (
 	"sync"
 	"testing"
 
-	pb "github.com/apache/beam/sdks/go/pkg/beam/model/org_apache_beam_runner_v1"
+	pb "github.com/apache/beam/sdks/go/pkg/beam/model/jobmanagement_v1"
 	"github.com/apache/beam/sdks/go/pkg/beam/util/grpcx"
 	"golang.org/x/net/context"
 	"google.golang.org/grpc"

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/sdks/go/pkg/beam/artifact/stage.go
----------------------------------------------------------------------
diff --git a/sdks/go/pkg/beam/artifact/stage.go b/sdks/go/pkg/beam/artifact/stage.go
index 8d97079..b87b320 100644
--- a/sdks/go/pkg/beam/artifact/stage.go
+++ b/sdks/go/pkg/beam/artifact/stage.go
@@ -30,7 +30,7 @@ import (
 	"sync"
 	"time"
 
-	pb "github.com/apache/beam/sdks/go/pkg/beam/model/org_apache_beam_runner_v1"
+	pb "github.com/apache/beam/sdks/go/pkg/beam/model/jobmanagement_v1"
 	"github.com/apache/beam/sdks/go/pkg/beam/util/errorx"
 )
 

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/sdks/go/pkg/beam/artifact/stage_test.go
----------------------------------------------------------------------
diff --git a/sdks/go/pkg/beam/artifact/stage_test.go b/sdks/go/pkg/beam/artifact/stage_test.go
index a371443..f9b5005 100644
--- a/sdks/go/pkg/beam/artifact/stage_test.go
+++ b/sdks/go/pkg/beam/artifact/stage_test.go
@@ -21,7 +21,7 @@ import (
 	"os"
 	"testing"
 
-	pb "github.com/apache/beam/sdks/go/pkg/beam/model/org_apache_beam_runner_v1"
+	pb "github.com/apache/beam/sdks/go/pkg/beam/model/jobmanagement_v1"
 	"github.com/apache/beam/sdks/go/pkg/beam/util/grpcx"
 	"google.golang.org/grpc"
 )

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/sdks/go/pkg/beam/model/fnexecution_v1/beam_provision_api.pb.go
----------------------------------------------------------------------
diff --git a/sdks/go/pkg/beam/model/fnexecution_v1/beam_provision_api.pb.go b/sdks/go/pkg/beam/model/fnexecution_v1/beam_provision_api.pb.go
new file mode 100644
index 0000000..0f452cc
--- /dev/null
+++ b/sdks/go/pkg/beam/model/fnexecution_v1/beam_provision_api.pb.go
@@ -0,0 +1,206 @@
+// Code generated by protoc-gen-go. DO NOT EDIT.
+// source: beam_provision_api.proto
+
+/*
+Package fnexecution_v1 is a generated protocol buffer package.
+
+It is generated from these files:
+	beam_provision_api.proto
+
+It has these top-level messages:
+	GetProvisionInfoRequest
+	GetProvisionInfoResponse
+	ProvisionInfo
+*/
+package fnexecution_v1
+
+import proto "github.com/golang/protobuf/proto"
+import fmt "fmt"
+import math "math"
+import google_protobuf "github.com/golang/protobuf/ptypes/struct"
+
+import (
+	context "golang.org/x/net/context"
+	grpc "google.golang.org/grpc"
+)
+
+// Reference imports to suppress errors if they are not otherwise used.
+var _ = proto.Marshal
+var _ = fmt.Errorf
+var _ = math.Inf
+
+// This is a compile-time assertion to ensure that this generated file
+// is compatible with the proto package it is being compiled against.
+// A compilation error at this line likely means your copy of the
+// proto package needs to be updated.
+const _ = proto.ProtoPackageIsVersion2 // please upgrade the proto package
+
+// A request to get the provision info of a SDK harness worker instance.
+type GetProvisionInfoRequest struct {
+}
+
+func (m *GetProvisionInfoRequest) Reset()                    { *m = GetProvisionInfoRequest{} }
+func (m *GetProvisionInfoRequest) String() string            { return proto.CompactTextString(m) }
+func (*GetProvisionInfoRequest) ProtoMessage()               {}
+func (*GetProvisionInfoRequest) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{0} }
+
+// A response containing the provision info of a SDK harness worker instance.
+type GetProvisionInfoResponse struct {
+	Info *ProvisionInfo `protobuf:"bytes,1,opt,name=info" json:"info,omitempty"`
+}
+
+func (m *GetProvisionInfoResponse) Reset()                    { *m = GetProvisionInfoResponse{} }
+func (m *GetProvisionInfoResponse) String() string            { return proto.CompactTextString(m) }
+func (*GetProvisionInfoResponse) ProtoMessage()               {}
+func (*GetProvisionInfoResponse) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{1} }
+
+func (m *GetProvisionInfoResponse) GetInfo() *ProvisionInfo {
+	if m != nil {
+		return m.Info
+	}
+	return nil
+}
+
+// Runtime provisioning information for a SDK harness worker instance,
+// such as pipeline options, resource constraints and other job metadata
+type ProvisionInfo struct {
+	// (required) The job ID.
+	JobId string `protobuf:"bytes,1,opt,name=job_id,json=jobId" json:"job_id,omitempty"`
+	// (required) The job name.
+	JobName string `protobuf:"bytes,2,opt,name=job_name,json=jobName" json:"job_name,omitempty"`
+	// (required) Pipeline options. For non-template jobs, the options are
+	// identical to what is passed to job submission.
+	PipelineOptions *google_protobuf.Struct `protobuf:"bytes,3,opt,name=pipeline_options,json=pipelineOptions" json:"pipeline_options,omitempty"`
+}
+
+func (m *ProvisionInfo) Reset()                    { *m = ProvisionInfo{} }
+func (m *ProvisionInfo) String() string            { return proto.CompactTextString(m) }
+func (*ProvisionInfo) ProtoMessage()               {}
+func (*ProvisionInfo) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{2} }
+
+func (m *ProvisionInfo) GetJobId() string {
+	if m != nil {
+		return m.JobId
+	}
+	return ""
+}
+
+func (m *ProvisionInfo) GetJobName() string {
+	if m != nil {
+		return m.JobName
+	}
+	return ""
+}
+
+func (m *ProvisionInfo) GetPipelineOptions() *google_protobuf.Struct {
+	if m != nil {
+		return m.PipelineOptions
+	}
+	return nil
+}
+
+func init() {
+	proto.RegisterType((*GetProvisionInfoRequest)(nil), "org.apache.beam.model.fn_execution.v1.GetProvisionInfoRequest")
+	proto.RegisterType((*GetProvisionInfoResponse)(nil), "org.apache.beam.model.fn_execution.v1.GetProvisionInfoResponse")
+	proto.RegisterType((*ProvisionInfo)(nil), "org.apache.beam.model.fn_execution.v1.ProvisionInfo")
+}
+
+// Reference imports to suppress errors if they are not otherwise used.
+var _ context.Context
+var _ grpc.ClientConn
+
+// This is a compile-time assertion to ensure that this generated file
+// is compatible with the grpc package it is being compiled against.
+const _ = grpc.SupportPackageIsVersion4
+
+// Client API for ProvisionService service
+
+type ProvisionServiceClient interface {
+	// Get provision information for the SDK harness worker instance.
+	GetProvisionInfo(ctx context.Context, in *GetProvisionInfoRequest, opts ...grpc.CallOption) (*GetProvisionInfoResponse, error)
+}
+
+type provisionServiceClient struct {
+	cc *grpc.ClientConn
+}
+
+func NewProvisionServiceClient(cc *grpc.ClientConn) ProvisionServiceClient {
+	return &provisionServiceClient{cc}
+}
+
+func (c *provisionServiceClient) GetProvisionInfo(ctx context.Context, in *GetProvisionInfoRequest, opts ...grpc.CallOption) (*GetProvisionInfoResponse, error) {
+	out := new(GetProvisionInfoResponse)
+	err := grpc.Invoke(ctx, "/org.apache.beam.model.fn_execution.v1.ProvisionService/GetProvisionInfo", in, out, c.cc, opts...)
+	if err != nil {
+		return nil, err
+	}
+	return out, nil
+}
+
+// Server API for ProvisionService service
+
+type ProvisionServiceServer interface {
+	// Get provision information for the SDK harness worker instance.
+	GetProvisionInfo(context.Context, *GetProvisionInfoRequest) (*GetProvisionInfoResponse, error)
+}
+
+func RegisterProvisionServiceServer(s *grpc.Server, srv ProvisionServiceServer) {
+	s.RegisterService(&_ProvisionService_serviceDesc, srv)
+}
+
+func _ProvisionService_GetProvisionInfo_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) {
+	in := new(GetProvisionInfoRequest)
+	if err := dec(in); err != nil {
+		return nil, err
+	}
+	if interceptor == nil {
+		return srv.(ProvisionServiceServer).GetProvisionInfo(ctx, in)
+	}
+	info := &grpc.UnaryServerInfo{
+		Server:     srv,
+		FullMethod: "/org.apache.beam.model.fn_execution.v1.ProvisionService/GetProvisionInfo",
+	}
+	handler := func(ctx context.Context, req interface{}) (interface{}, error) {
+		return srv.(ProvisionServiceServer).GetProvisionInfo(ctx, req.(*GetProvisionInfoRequest))
+	}
+	return interceptor(ctx, in, info, handler)
+}
+
+var _ProvisionService_serviceDesc = grpc.ServiceDesc{
+	ServiceName: "org.apache.beam.model.fn_execution.v1.ProvisionService",
+	HandlerType: (*ProvisionServiceServer)(nil),
+	Methods: []grpc.MethodDesc{
+		{
+			MethodName: "GetProvisionInfo",
+			Handler:    _ProvisionService_GetProvisionInfo_Handler,
+		},
+	},
+	Streams:  []grpc.StreamDesc{},
+	Metadata: "beam_provision_api.proto",
+}
+
+func init() { proto.RegisterFile("beam_provision_api.proto", fileDescriptor0) }
+
+var fileDescriptor0 = []byte{
+	// 311 bytes of a gzipped FileDescriptorProto
+	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x9c, 0x90, 0xcd, 0x4a, 0x03, 0x31,
+	0x14, 0x85, 0x19, 0x7f, 0xaa, 0xc6, 0xbf, 0x12, 0x90, 0x4e, 0x8b, 0x0b, 0x29, 0x0a, 0xae, 0x52,
+	0x5a, 0x5d, 0x2b, 0x16, 0x41, 0xbb, 0x51, 0x69, 0x77, 0x6e, 0x42, 0x32, 0x73, 0xa7, 0xa6, 0x74,
+	0x72, 0xe3, 0x24, 0x33, 0xf8, 0x02, 0x3e, 0x81, 0x2f, 0xe1, 0x63, 0x4a, 0x33, 0x4c, 0x69, 0x95,
+	0x42, 0x71, 0x9b, 0x73, 0xcf, 0x97, 0x73, 0x0e, 0x09, 0x25, 0x88, 0x94, 0x9b, 0x0c, 0x0b, 0x65,
+	0x15, 0x6a, 0x2e, 0x8c, 0x62, 0x26, 0x43, 0x87, 0xf4, 0x02, 0xb3, 0x31, 0x13, 0x46, 0x44, 0x6f,
+	0xc0, 0x66, 0x47, 0x2c, 0xc5, 0x18, 0xa6, 0x2c, 0xd1, 0x1c, 0x3e, 0x20, 0xca, 0x9d, 0x42, 0xcd,
+	0x8a, 0x6e, 0xeb, 0x74, 0x8c, 0x38, 0x9e, 0x42, 0xc7, 0x9b, 0x64, 0x9e, 0x74, 0xac, 0xcb, 0xf2,
+	0xc8, 0x95, 0x90, 0x76, 0x93, 0x34, 0x1e, 0xc0, 0xbd, 0x54, 0xf8, 0x81, 0x4e, 0x70, 0x08, 0xef,
+	0x39, 0x58, 0xd7, 0x8e, 0x49, 0xf8, 0x57, 0xb2, 0x06, 0xb5, 0x05, 0xfa, 0x48, 0xb6, 0x94, 0x4e,
+	0x30, 0x0c, 0xce, 0x82, 0xcb, 0xfd, 0xde, 0x35, 0x5b, 0x2b, 0x0a, 0x5b, 0x66, 0x79, 0x42, 0xfb,
+	0x33, 0x20, 0x87, 0x4b, 0xef, 0xf4, 0x84, 0xd4, 0x26, 0x28, 0xb9, 0x8a, 0x3d, 0x7d, 0x6f, 0xb8,
+	0x3d, 0x41, 0x39, 0x88, 0x69, 0x93, 0xec, 0xce, 0x9e, 0xb5, 0x48, 0x21, 0xdc, 0xf0, 0xc2, 0xce,
+	0x04, 0xe5, 0x93, 0x48, 0x81, 0xf6, 0x49, 0xdd, 0x28, 0x03, 0x53, 0xa5, 0x81, 0xa3, 0x99, 0xfd,
+	0x66, 0xc3, 0x4d, 0x9f, 0xac, 0xc1, 0xca, 0xf6, 0xac, 0x6a, 0xcf, 0x46, 0xbe, 0xfd, 0xf0, 0xb8,
+	0x32, 0x3c, 0x97, 0xf7, 0xbd, 0xef, 0x80, 0xd4, 0xe7, 0x39, 0x46, 0x90, 0x15, 0x2a, 0x02, 0xfa,
+	0x15, 0x90, 0xfa, 0xef, 0x0d, 0xe8, 0xcd, 0x9a, 0x6d, 0x57, 0xec, 0xda, 0xba, 0xfd, 0xb7, 0xbf,
+	0x1c, 0xbf, 0x7f, 0x4f, 0xce, 0x57, 0x11, 0x16, 0x01, 0xfd, 0x83, 0xb9, 0xfd, 0xce, 0xa8, 0xd7,
+	0xa3, 0x05, 0x95, 0x17, 0x5d, 0x59, 0xf3, 0x93, 0x5c, 0xfd, 0x04, 0x00, 0x00, 0xff, 0xff, 0x2e,
+	0xae, 0x1f, 0x23, 0x61, 0x02, 0x00, 0x00,
+}

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/sdks/go/pkg/beam/model/gen.go
----------------------------------------------------------------------
diff --git a/sdks/go/pkg/beam/model/gen.go b/sdks/go/pkg/beam/model/gen.go
index 9bff5e0..d20007d 100644
--- a/sdks/go/pkg/beam/model/gen.go
+++ b/sdks/go/pkg/beam/model/gen.go
@@ -17,5 +17,5 @@ package model
 
 // TODO(herohde) 9/1/2017: for now, install protoc as described on grpc.io before running go generate.
 
-//go:generate protoc -I../../../../common/runner-api/src/main/proto ../../../../common/runner-api/src/main/proto/beam_artifact_api.proto --go_out=org_apache_beam_runner_v1,plugins=grpc:org_apache_beam_runner_v1
-//go:generate protoc -I../../../../common/fn-api/src/main/proto ../../../../common/fn-api/src/main/proto/beam_provision_api.proto --go_out=org_apache_beam_fn_v1,plugins=grpc:org_apache_beam_fn_v1
+//go:generate protoc -I../../../../../model/job-management/src/main/proto ../../../../../model/job-management/src/main/proto/beam_artifact_api.proto --go_out=jobmanagement_v1,plugins=grpc:jobmanagement_v1
+//go:generate protoc -I../../../../../model/fn-execution/src/main/proto ../../../../../model/fn-execution/src/main/proto/beam_provision_api.proto --go_out=fnexecution_v1,plugins=grpc:fnexecution_v1

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/sdks/go/pkg/beam/model/jobmanagement_v1/beam_artifact_api.pb.go
----------------------------------------------------------------------
diff --git a/sdks/go/pkg/beam/model/jobmanagement_v1/beam_artifact_api.pb.go b/sdks/go/pkg/beam/model/jobmanagement_v1/beam_artifact_api.pb.go
new file mode 100644
index 0000000..2159757
--- /dev/null
+++ b/sdks/go/pkg/beam/model/jobmanagement_v1/beam_artifact_api.pb.go
@@ -0,0 +1,715 @@
+// Code generated by protoc-gen-go. DO NOT EDIT.
+// source: beam_artifact_api.proto
+
+/*
+Package jobmanagement_v1 is a generated protocol buffer package.
+
+It is generated from these files:
+	beam_artifact_api.proto
+
+It has these top-level messages:
+	ArtifactMetadata
+	Manifest
+	ProxyManifest
+	GetManifestRequest
+	GetManifestResponse
+	GetArtifactRequest
+	ArtifactChunk
+	PutArtifactRequest
+	PutArtifactResponse
+	CommitManifestRequest
+	CommitManifestResponse
+*/
+package jobmanagement_v1
+
+import proto "github.com/golang/protobuf/proto"
+import fmt "fmt"
+import math "math"
+
+import (
+	context "golang.org/x/net/context"
+	grpc "google.golang.org/grpc"
+)
+
+// Reference imports to suppress errors if they are not otherwise used.
+var _ = proto.Marshal
+var _ = fmt.Errorf
+var _ = math.Inf
+
+// This is a compile-time assertion to ensure that this generated file
+// is compatible with the proto package it is being compiled against.
+// A compilation error at this line likely means your copy of the
+// proto package needs to be updated.
+const _ = proto.ProtoPackageIsVersion2 // please upgrade the proto package
+
+// An artifact identifier and associated metadata.
+type ArtifactMetadata struct {
+	// (Required) The name of the artifact.
+	Name string `protobuf:"bytes,1,opt,name=name" json:"name,omitempty"`
+	// (Optional) The Unix-like permissions of the artifact
+	Permissions uint32 `protobuf:"varint,2,opt,name=permissions" json:"permissions,omitempty"`
+	// (Optional) The base64-encoded md5 checksum of the artifact. Used, among other things, by
+	// harness boot code to validate the integrity of the artifact.
+	Md5 string `protobuf:"bytes,3,opt,name=md5" json:"md5,omitempty"`
+}
+
+func (m *ArtifactMetadata) Reset()                    { *m = ArtifactMetadata{} }
+func (m *ArtifactMetadata) String() string            { return proto.CompactTextString(m) }
+func (*ArtifactMetadata) ProtoMessage()               {}
+func (*ArtifactMetadata) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{0} }
+
+func (m *ArtifactMetadata) GetName() string {
+	if m != nil {
+		return m.Name
+	}
+	return ""
+}
+
+func (m *ArtifactMetadata) GetPermissions() uint32 {
+	if m != nil {
+		return m.Permissions
+	}
+	return 0
+}
+
+func (m *ArtifactMetadata) GetMd5() string {
+	if m != nil {
+		return m.Md5
+	}
+	return ""
+}
+
+// A collection of artifacts.
+type Manifest struct {
+	Artifact []*ArtifactMetadata `protobuf:"bytes,1,rep,name=artifact" json:"artifact,omitempty"`
+}
+
+func (m *Manifest) Reset()                    { *m = Manifest{} }
+func (m *Manifest) String() string            { return proto.CompactTextString(m) }
+func (*Manifest) ProtoMessage()               {}
+func (*Manifest) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{1} }
+
+func (m *Manifest) GetArtifact() []*ArtifactMetadata {
+	if m != nil {
+		return m.Artifact
+	}
+	return nil
+}
+
+// A manifest with location information.
+type ProxyManifest struct {
+	Manifest *Manifest                 `protobuf:"bytes,1,opt,name=manifest" json:"manifest,omitempty"`
+	Location []*ProxyManifest_Location `protobuf:"bytes,2,rep,name=location" json:"location,omitempty"`
+}
+
+func (m *ProxyManifest) Reset()                    { *m = ProxyManifest{} }
+func (m *ProxyManifest) String() string            { return proto.CompactTextString(m) }
+func (*ProxyManifest) ProtoMessage()               {}
+func (*ProxyManifest) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{2} }
+
+func (m *ProxyManifest) GetManifest() *Manifest {
+	if m != nil {
+		return m.Manifest
+	}
+	return nil
+}
+
+func (m *ProxyManifest) GetLocation() []*ProxyManifest_Location {
+	if m != nil {
+		return m.Location
+	}
+	return nil
+}
+
+type ProxyManifest_Location struct {
+	Name string `protobuf:"bytes,1,opt,name=name" json:"name,omitempty"`
+	Uri  string `protobuf:"bytes,2,opt,name=uri" json:"uri,omitempty"`
+}
+
+func (m *ProxyManifest_Location) Reset()                    { *m = ProxyManifest_Location{} }
+func (m *ProxyManifest_Location) String() string            { return proto.CompactTextString(m) }
+func (*ProxyManifest_Location) ProtoMessage()               {}
+func (*ProxyManifest_Location) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{2, 0} }
+
+func (m *ProxyManifest_Location) GetName() string {
+	if m != nil {
+		return m.Name
+	}
+	return ""
+}
+
+func (m *ProxyManifest_Location) GetUri() string {
+	if m != nil {
+		return m.Uri
+	}
+	return ""
+}
+
+// A request to get the manifest of a Job.
+type GetManifestRequest struct {
+}
+
+func (m *GetManifestRequest) Reset()                    { *m = GetManifestRequest{} }
+func (m *GetManifestRequest) String() string            { return proto.CompactTextString(m) }
+func (*GetManifestRequest) ProtoMessage()               {}
+func (*GetManifestRequest) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{3} }
+
+// A response containing a job manifest.
+type GetManifestResponse struct {
+	Manifest *Manifest `protobuf:"bytes,1,opt,name=manifest" json:"manifest,omitempty"`
+}
+
+func (m *GetManifestResponse) Reset()                    { *m = GetManifestResponse{} }
+func (m *GetManifestResponse) String() string            { return proto.CompactTextString(m) }
+func (*GetManifestResponse) ProtoMessage()               {}
+func (*GetManifestResponse) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{4} }
+
+func (m *GetManifestResponse) GetManifest() *Manifest {
+	if m != nil {
+		return m.Manifest
+	}
+	return nil
+}
+
+// A request to get an artifact. The artifact must be present in the manifest for the job.
+type GetArtifactRequest struct {
+	// (Required) The name of the artifact to retrieve.
+	Name string `protobuf:"bytes,1,opt,name=name" json:"name,omitempty"`
+}
+
+func (m *GetArtifactRequest) Reset()                    { *m = GetArtifactRequest{} }
+func (m *GetArtifactRequest) String() string            { return proto.CompactTextString(m) }
+func (*GetArtifactRequest) ProtoMessage()               {}
+func (*GetArtifactRequest) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{5} }
+
+func (m *GetArtifactRequest) GetName() string {
+	if m != nil {
+		return m.Name
+	}
+	return ""
+}
+
+// Part of an artifact.
+type ArtifactChunk struct {
+	Data []byte `protobuf:"bytes,1,opt,name=data,proto3" json:"data,omitempty"`
+}
+
+func (m *ArtifactChunk) Reset()                    { *m = ArtifactChunk{} }
+func (m *ArtifactChunk) String() string            { return proto.CompactTextString(m) }
+func (*ArtifactChunk) ProtoMessage()               {}
+func (*ArtifactChunk) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{6} }
+
+func (m *ArtifactChunk) GetData() []byte {
+	if m != nil {
+		return m.Data
+	}
+	return nil
+}
+
+// A request to stage an artifact.
+type PutArtifactRequest struct {
+	// (Required)
+	//
+	// Types that are valid to be assigned to Content:
+	//	*PutArtifactRequest_Metadata
+	//	*PutArtifactRequest_Data
+	Content isPutArtifactRequest_Content `protobuf_oneof:"content"`
+}
+
+func (m *PutArtifactRequest) Reset()                    { *m = PutArtifactRequest{} }
+func (m *PutArtifactRequest) String() string            { return proto.CompactTextString(m) }
+func (*PutArtifactRequest) ProtoMessage()               {}
+func (*PutArtifactRequest) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{7} }
+
+type isPutArtifactRequest_Content interface {
+	isPutArtifactRequest_Content()
+}
+
+type PutArtifactRequest_Metadata struct {
+	Metadata *ArtifactMetadata `protobuf:"bytes,1,opt,name=metadata,oneof"`
+}
+type PutArtifactRequest_Data struct {
+	Data *ArtifactChunk `protobuf:"bytes,2,opt,name=data,oneof"`
+}
+
+func (*PutArtifactRequest_Metadata) isPutArtifactRequest_Content() {}
+func (*PutArtifactRequest_Data) isPutArtifactRequest_Content()     {}
+
+func (m *PutArtifactRequest) GetContent() isPutArtifactRequest_Content {
+	if m != nil {
+		return m.Content
+	}
+	return nil
+}
+
+func (m *PutArtifactRequest) GetMetadata() *ArtifactMetadata {
+	if x, ok := m.GetContent().(*PutArtifactRequest_Metadata); ok {
+		return x.Metadata
+	}
+	return nil
+}
+
+func (m *PutArtifactRequest) GetData() *ArtifactChunk {
+	if x, ok := m.GetContent().(*PutArtifactRequest_Data); ok {
+		return x.Data
+	}
+	return nil
+}
+
+// XXX_OneofFuncs is for the internal use of the proto package.
+func (*PutArtifactRequest) 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{}) {
+	return _PutArtifactRequest_OneofMarshaler, _PutArtifactRequest_OneofUnmarshaler, _PutArtifactRequest_OneofSizer, []interface{}{
+		(*PutArtifactRequest_Metadata)(nil),
+		(*PutArtifactRequest_Data)(nil),
+	}
+}
+
+func _PutArtifactRequest_OneofMarshaler(msg proto.Message, b *proto.Buffer) error {
+	m := msg.(*PutArtifactRequest)
+	// content
+	switch x := m.Content.(type) {
+	case *PutArtifactRequest_Metadata:
+		b.EncodeVarint(1<<3 | proto.WireBytes)
+		if err := b.EncodeMessage(x.Metadata); err != nil {
+			return err
+		}
+	case *PutArtifactRequest_Data:
+		b.EncodeVarint(2<<3 | proto.WireBytes)
+		if err := b.EncodeMessage(x.Data); err != nil {
+			return err
+		}
+	case nil:
+	default:
+		return fmt.Errorf("PutArtifactRequest.Content has unexpected type %T", x)
+	}
+	return nil
+}
+
+func _PutArtifactRequest_OneofUnmarshaler(msg proto.Message, tag, wire int, b *proto.Buffer) (bool, error) {
+	m := msg.(*PutArtifactRequest)
+	switch tag {
+	case 1: // content.metadata
+		if wire != proto.WireBytes {
+			return true, proto.ErrInternalBadWireType
+		}
+		msg := new(ArtifactMetadata)
+		err := b.DecodeMessage(msg)
+		m.Content = &PutArtifactRequest_Metadata{msg}
+		return true, err
+	case 2: // content.data
+		if wire != proto.WireBytes {
+			return true, proto.ErrInternalBadWireType
+		}
+		msg := new(ArtifactChunk)
+		err := b.DecodeMessage(msg)
+		m.Content = &PutArtifactRequest_Data{msg}
+		return true, err
+	default:
+		return false, nil
+	}
+}
+
+func _PutArtifactRequest_OneofSizer(msg proto.Message) (n int) {
+	m := msg.(*PutArtifactRequest)
+	// content
+	switch x := m.Content.(type) {
+	case *PutArtifactRequest_Metadata:
+		s := proto.Size(x.Metadata)
+		n += proto.SizeVarint(1<<3 | proto.WireBytes)
+		n += proto.SizeVarint(uint64(s))
+		n += s
+	case *PutArtifactRequest_Data:
+		s := proto.Size(x.Data)
+		n += proto.SizeVarint(2<<3 | proto.WireBytes)
+		n += proto.SizeVarint(uint64(s))
+		n += s
+	case nil:
+	default:
+		panic(fmt.Sprintf("proto: unexpected type %T in oneof", x))
+	}
+	return n
+}
+
+type PutArtifactResponse struct {
+}
+
+func (m *PutArtifactResponse) Reset()                    { *m = PutArtifactResponse{} }
+func (m *PutArtifactResponse) String() string            { return proto.CompactTextString(m) }
+func (*PutArtifactResponse) ProtoMessage()               {}
+func (*PutArtifactResponse) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{8} }
+
+// A request to commit the manifest for a Job. All artifacts must have been successfully uploaded
+// before this call is made.
+type CommitManifestRequest struct {
+	// (Required) The manifest to commit.
+	Manifest *Manifest `protobuf:"bytes,1,opt,name=manifest" json:"manifest,omitempty"`
+}
+
+func (m *CommitManifestRequest) Reset()                    { *m = CommitManifestRequest{} }
+func (m *CommitManifestRequest) String() string            { return proto.CompactTextString(m) }
+func (*CommitManifestRequest) ProtoMessage()               {}
+func (*CommitManifestRequest) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{9} }
+
+func (m *CommitManifestRequest) GetManifest() *Manifest {
+	if m != nil {
+		return m.Manifest
+	}
+	return nil
+}
+
+// The result of committing a manifest.
+type CommitManifestResponse struct {
+	// (Required) An opaque token representing the entirety of the staged artifacts.
+	StagingToken string `protobuf:"bytes,1,opt,name=staging_token,json=stagingToken" json:"staging_token,omitempty"`
+}
+
+func (m *CommitManifestResponse) Reset()                    { *m = CommitManifestResponse{} }
+func (m *CommitManifestResponse) String() string            { return proto.CompactTextString(m) }
+func (*CommitManifestResponse) ProtoMessage()               {}
+func (*CommitManifestResponse) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{10} }
+
+func (m *CommitManifestResponse) GetStagingToken() string {
+	if m != nil {
+		return m.StagingToken
+	}
+	return ""
+}
+
+func init() {
+	proto.RegisterType((*ArtifactMetadata)(nil), "org.apache.beam.model.job_management.v1.ArtifactMetadata")
+	proto.RegisterType((*Manifest)(nil), "org.apache.beam.model.job_management.v1.Manifest")
+	proto.RegisterType((*ProxyManifest)(nil), "org.apache.beam.model.job_management.v1.ProxyManifest")
+	proto.RegisterType((*ProxyManifest_Location)(nil), "org.apache.beam.model.job_management.v1.ProxyManifest.Location")
+	proto.RegisterType((*GetManifestRequest)(nil), "org.apache.beam.model.job_management.v1.GetManifestRequest")
+	proto.RegisterType((*GetManifestResponse)(nil), "org.apache.beam.model.job_management.v1.GetManifestResponse")
+	proto.RegisterType((*GetArtifactRequest)(nil), "org.apache.beam.model.job_management.v1.GetArtifactRequest")
+	proto.RegisterType((*ArtifactChunk)(nil), "org.apache.beam.model.job_management.v1.ArtifactChunk")
+	proto.RegisterType((*PutArtifactRequest)(nil), "org.apache.beam.model.job_management.v1.PutArtifactRequest")
+	proto.RegisterType((*PutArtifactResponse)(nil), "org.apache.beam.model.job_management.v1.PutArtifactResponse")
+	proto.RegisterType((*CommitManifestRequest)(nil), "org.apache.beam.model.job_management.v1.CommitManifestRequest")
+	proto.RegisterType((*CommitManifestResponse)(nil), "org.apache.beam.model.job_management.v1.CommitManifestResponse")
+}
+
+// Reference imports to suppress errors if they are not otherwise used.
+var _ context.Context
+var _ grpc.ClientConn
+
+// This is a compile-time assertion to ensure that this generated file
+// is compatible with the grpc package it is being compiled against.
+const _ = grpc.SupportPackageIsVersion4
+
+// Client API for ArtifactStagingService service
+
+type ArtifactStagingServiceClient interface {
+	// Stage an artifact to be available during job execution. The first request must contain the
+	// name of the artifact. All future requests must contain sequential chunks of the content of
+	// the artifact.
+	PutArtifact(ctx context.Context, opts ...grpc.CallOption) (ArtifactStagingService_PutArtifactClient, error)
+	// Commit the manifest for a Job. All artifacts must have been successfully uploaded
+	// before this call is made.
+	//
+	// Throws error INVALID_ARGUMENT if not all of the members of the manifest are present
+	CommitManifest(ctx context.Context, in *CommitManifestRequest, opts ...grpc.CallOption) (*CommitManifestResponse, error)
+}
+
+type artifactStagingServiceClient struct {
+	cc *grpc.ClientConn
+}
+
+func NewArtifactStagingServiceClient(cc *grpc.ClientConn) ArtifactStagingServiceClient {
+	return &artifactStagingServiceClient{cc}
+}
+
+func (c *artifactStagingServiceClient) PutArtifact(ctx context.Context, opts ...grpc.CallOption) (ArtifactStagingService_PutArtifactClient, error) {
+	stream, err := grpc.NewClientStream(ctx, &_ArtifactStagingService_serviceDesc.Streams[0], c.cc, "/org.apache.beam.model.job_management.v1.ArtifactStagingService/PutArtifact", opts...)
+	if err != nil {
+		return nil, err
+	}
+	x := &artifactStagingServicePutArtifactClient{stream}
+	return x, nil
+}
+
+type ArtifactStagingService_PutArtifactClient interface {
+	Send(*PutArtifactRequest) error
+	CloseAndRecv() (*PutArtifactResponse, error)
+	grpc.ClientStream
+}
+
+type artifactStagingServicePutArtifactClient struct {
+	grpc.ClientStream
+}
+
+func (x *artifactStagingServicePutArtifactClient) Send(m *PutArtifactRequest) error {
+	return x.ClientStream.SendMsg(m)
+}
+
+func (x *artifactStagingServicePutArtifactClient) CloseAndRecv() (*PutArtifactResponse, error) {
+	if err := x.ClientStream.CloseSend(); err != nil {
+		return nil, err
+	}
+	m := new(PutArtifactResponse)
+	if err := x.ClientStream.RecvMsg(m); err != nil {
+		return nil, err
+	}
+	return m, nil
+}
+
+func (c *artifactStagingServiceClient) CommitManifest(ctx context.Context, in *CommitManifestRequest, opts ...grpc.CallOption) (*CommitManifestResponse, error) {
+	out := new(CommitManifestResponse)
+	err := grpc.Invoke(ctx, "/org.apache.beam.model.job_management.v1.ArtifactStagingService/CommitManifest", in, out, c.cc, opts...)
+	if err != nil {
+		return nil, err
+	}
+	return out, nil
+}
+
+// Server API for ArtifactStagingService service
+
+type ArtifactStagingServiceServer interface {
+	// Stage an artifact to be available during job execution. The first request must contain the
+	// name of the artifact. All future requests must contain sequential chunks of the content of
+	// the artifact.
+	PutArtifact(ArtifactStagingService_PutArtifactServer) error
+	// Commit the manifest for a Job. All artifacts must have been successfully uploaded
+	// before this call is made.
+	//
+	// Throws error INVALID_ARGUMENT if not all of the members of the manifest are present
+	CommitManifest(context.Context, *CommitManifestRequest) (*CommitManifestResponse, error)
+}
+
+func RegisterArtifactStagingServiceServer(s *grpc.Server, srv ArtifactStagingServiceServer) {
+	s.RegisterService(&_ArtifactStagingService_serviceDesc, srv)
+}
+
+func _ArtifactStagingService_PutArtifact_Handler(srv interface{}, stream grpc.ServerStream) error {
+	return srv.(ArtifactStagingServiceServer).PutArtifact(&artifactStagingServicePutArtifactServer{stream})
+}
+
+type ArtifactStagingService_PutArtifactServer interface {
+	SendAndClose(*PutArtifactResponse) error
+	Recv() (*PutArtifactRequest, error)
+	grpc.ServerStream
+}
+
+type artifactStagingServicePutArtifactServer struct {
+	grpc.ServerStream
+}
+
+func (x *artifactStagingServicePutArtifactServer) SendAndClose(m *PutArtifactResponse) error {
+	return x.ServerStream.SendMsg(m)
+}
+
+func (x *artifactStagingServicePutArtifactServer) Recv() (*PutArtifactRequest, error) {
+	m := new(PutArtifactRequest)
+	if err := x.ServerStream.RecvMsg(m); err != nil {
+		return nil, err
+	}
+	return m, nil
+}
+
+func _ArtifactStagingService_CommitManifest_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) {
+	in := new(CommitManifestRequest)
+	if err := dec(in); err != nil {
+		return nil, err
+	}
+	if interceptor == nil {
+		return srv.(ArtifactStagingServiceServer).CommitManifest(ctx, in)
+	}
+	info := &grpc.UnaryServerInfo{
+		Server:     srv,
+		FullMethod: "/org.apache.beam.model.job_management.v1.ArtifactStagingService/CommitManifest",
+	}
+	handler := func(ctx context.Context, req interface{}) (interface{}, error) {
+		return srv.(ArtifactStagingServiceServer).CommitManifest(ctx, req.(*CommitManifestRequest))
+	}
+	return interceptor(ctx, in, info, handler)
+}
+
+var _ArtifactStagingService_serviceDesc = grpc.ServiceDesc{
+	ServiceName: "org.apache.beam.model.job_management.v1.ArtifactStagingService",
+	HandlerType: (*ArtifactStagingServiceServer)(nil),
+	Methods: []grpc.MethodDesc{
+		{
+			MethodName: "CommitManifest",
+			Handler:    _ArtifactStagingService_CommitManifest_Handler,
+		},
+	},
+	Streams: []grpc.StreamDesc{
+		{
+			StreamName:    "PutArtifact",
+			Handler:       _ArtifactStagingService_PutArtifact_Handler,
+			ClientStreams: true,
+		},
+	},
+	Metadata: "beam_artifact_api.proto",
+}
+
+// Client API for ArtifactRetrievalService service
+
+type ArtifactRetrievalServiceClient interface {
+	// Get the manifest for the job
+	GetManifest(ctx context.Context, in *GetManifestRequest, opts ...grpc.CallOption) (*GetManifestResponse, error)
+	// Get an artifact staged for the job. The requested artifact must be within the manifest
+	GetArtifact(ctx context.Context, in *GetArtifactRequest, opts ...grpc.CallOption) (ArtifactRetrievalService_GetArtifactClient, error)
+}
+
+type artifactRetrievalServiceClient struct {
+	cc *grpc.ClientConn
+}
+
+func NewArtifactRetrievalServiceClient(cc *grpc.ClientConn) ArtifactRetrievalServiceClient {
+	return &artifactRetrievalServiceClient{cc}
+}
+
+func (c *artifactRetrievalServiceClient) GetManifest(ctx context.Context, in *GetManifestRequest, opts ...grpc.CallOption) (*GetManifestResponse, error) {
+	out := new(GetManifestResponse)
+	err := grpc.Invoke(ctx, "/org.apache.beam.model.job_management.v1.ArtifactRetrievalService/GetManifest", in, out, c.cc, opts...)
+	if err != nil {
+		return nil, err
+	}
+	return out, nil
+}
+
+func (c *artifactRetrievalServiceClient) GetArtifact(ctx context.Context, in *GetArtifactRequest, opts ...grpc.CallOption) (ArtifactRetrievalService_GetArtifactClient, error) {
+	stream, err := grpc.NewClientStream(ctx, &_ArtifactRetrievalService_serviceDesc.Streams[0], c.cc, "/org.apache.beam.model.job_management.v1.ArtifactRetrievalService/GetArtifact", opts...)
+	if err != nil {
+		return nil, err
+	}
+	x := &artifactRetrievalServiceGetArtifactClient{stream}
+	if err := x.ClientStream.SendMsg(in); err != nil {
+		return nil, err
+	}
+	if err := x.ClientStream.CloseSend(); err != nil {
+		return nil, err
+	}
+	return x, nil
+}
+
+type ArtifactRetrievalService_GetArtifactClient interface {
+	Recv() (*ArtifactChunk, error)
+	grpc.ClientStream
+}
+
+type artifactRetrievalServiceGetArtifactClient struct {
+	grpc.ClientStream
+}
+
+func (x *artifactRetrievalServiceGetArtifactClient) Recv() (*ArtifactChunk, error) {
+	m := new(ArtifactChunk)
+	if err := x.ClientStream.RecvMsg(m); err != nil {
+		return nil, err
+	}
+	return m, nil
+}
+
+// Server API for ArtifactRetrievalService service
+
+type ArtifactRetrievalServiceServer interface {
+	// Get the manifest for the job
+	GetManifest(context.Context, *GetManifestRequest) (*GetManifestResponse, error)
+	// Get an artifact staged for the job. The requested artifact must be within the manifest
+	GetArtifact(*GetArtifactRequest, ArtifactRetrievalService_GetArtifactServer) error
+}
+
+func RegisterArtifactRetrievalServiceServer(s *grpc.Server, srv ArtifactRetrievalServiceServer) {
+	s.RegisterService(&_ArtifactRetrievalService_serviceDesc, srv)
+}
+
+func _ArtifactRetrievalService_GetManifest_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) {
+	in := new(GetManifestRequest)
+	if err := dec(in); err != nil {
+		return nil, err
+	}
+	if interceptor == nil {
+		return srv.(ArtifactRetrievalServiceServer).GetManifest(ctx, in)
+	}
+	info := &grpc.UnaryServerInfo{
+		Server:     srv,
+		FullMethod: "/org.apache.beam.model.job_management.v1.ArtifactRetrievalService/GetManifest",
+	}
+	handler := func(ctx context.Context, req interface{}) (interface{}, error) {
+		return srv.(ArtifactRetrievalServiceServer).GetManifest(ctx, req.(*GetManifestRequest))
+	}
+	return interceptor(ctx, in, info, handler)
+}
+
+func _ArtifactRetrievalService_GetArtifact_Handler(srv interface{}, stream grpc.ServerStream) error {
+	m := new(GetArtifactRequest)
+	if err := stream.RecvMsg(m); err != nil {
+		return err
+	}
+	return srv.(ArtifactRetrievalServiceServer).GetArtifact(m, &artifactRetrievalServiceGetArtifactServer{stream})
+}
+
+type ArtifactRetrievalService_GetArtifactServer interface {
+	Send(*ArtifactChunk) error
+	grpc.ServerStream
+}
+
+type artifactRetrievalServiceGetArtifactServer struct {
+	grpc.ServerStream
+}
+
+func (x *artifactRetrievalServiceGetArtifactServer) Send(m *ArtifactChunk) error {
+	return x.ServerStream.SendMsg(m)
+}
+
+var _ArtifactRetrievalService_serviceDesc = grpc.ServiceDesc{
+	ServiceName: "org.apache.beam.model.job_management.v1.ArtifactRetrievalService",
+	HandlerType: (*ArtifactRetrievalServiceServer)(nil),
+	Methods: []grpc.MethodDesc{
+		{
+			MethodName: "GetManifest",
+			Handler:    _ArtifactRetrievalService_GetManifest_Handler,
+		},
+	},
+	Streams: []grpc.StreamDesc{
+		{
+			StreamName:    "GetArtifact",
+			Handler:       _ArtifactRetrievalService_GetArtifact_Handler,
+			ServerStreams: true,
+		},
+	},
+	Metadata: "beam_artifact_api.proto",
+}
+
+func init() { proto.RegisterFile("beam_artifact_api.proto", fileDescriptor0) }
+
+var fileDescriptor0 = []byte{
+	// 557 bytes of a gzipped FileDescriptorProto
+	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0xac, 0x55, 0xcf, 0x6e, 0xd3, 0x4e,
+	0x10, 0xee, 0x26, 0x3f, 0xfd, 0x70, 0xc6, 0x0d, 0x8a, 0xb6, 0xb4, 0x58, 0x39, 0x45, 0x5b, 0x09,
+	0x72, 0xb2, 0x9a, 0x20, 0x90, 0x10, 0x7f, 0xaa, 0xa6, 0x87, 0xf6, 0xd0, 0x48, 0x95, 0x0b, 0x42,
+	0x2a, 0x87, 0x68, 0x93, 0x6c, 0xd2, 0xa5, 0xd9, 0x5d, 0x63, 0x6f, 0x22, 0xb8, 0x73, 0x40, 0xdc,
+	0x78, 0x0f, 0x5e, 0x80, 0x17, 0xe0, 0x6d, 0x78, 0x07, 0xe4, 0xf5, 0xda, 0xc4, 0x49, 0x90, 0x92,
+	0xa8, 0xb7, 0xd1, 0x78, 0xe6, 0x9b, 0x6f, 0xbe, 0x6f, 0x27, 0x81, 0x87, 0x7d, 0x46, 0x45, 0x8f,
+	0x46, 0x9a, 0x8f, 0xe8, 0x40, 0xf7, 0x68, 0xc8, 0xfd, 0x30, 0x52, 0x5a, 0xe1, 0xc7, 0x2a, 0x1a,
+	0xfb, 0x34, 0xa4, 0x83, 0x1b, 0xe6, 0x27, 0x35, 0xbe, 0x50, 0x43, 0x36, 0xf1, 0x3f, 0xa8, 0x7e,
+	0x4f, 0x50, 0x49, 0xc7, 0x4c, 0x30, 0xa9, 0xfd, 0x59, 0x8b, 0x5c, 0x43, 0xed, 0xc4, 0xb6, 0x77,
+	0x99, 0xa6, 0x43, 0xaa, 0x29, 0xc6, 0xf0, 0x9f, 0xa4, 0x82, 0x79, 0xa8, 0x81, 0x9a, 0x95, 0xc0,
+	0xc4, 0xb8, 0x01, 0x6e, 0xc8, 0x22, 0xc1, 0xe3, 0x98, 0x2b, 0x19, 0x7b, 0xa5, 0x06, 0x6a, 0x56,
+	0x83, 0xf9, 0x14, 0xae, 0x41, 0x59, 0x0c, 0x9f, 0x7a, 0x65, 0xd3, 0x94, 0x84, 0x84, 0x82, 0xd3,
+	0xa5, 0x92, 0x8f, 0x58, 0xac, 0xf1, 0x5b, 0x70, 0x32, 0x9a, 0x1e, 0x6a, 0x94, 0x9b, 0x6e, 0xfb,
+	0xb9, 0xbf, 0x26, 0x47, 0x7f, 0x91, 0x60, 0x90, 0x43, 0x91, 0xdf, 0x08, 0xaa, 0x97, 0x91, 0xfa,
+	0xf4, 0x39, 0x1f, 0xd4, 0x05, 0x47, 0xd8, 0xd8, 0x2c, 0xe0, 0xb6, 0x5b, 0x6b, 0x0f, 0xca, 0x40,
+	0x82, 0x1c, 0x02, 0xbf, 0x07, 0x67, 0xa2, 0x06, 0x54, 0x73, 0x25, 0xbd, 0x92, 0xe1, 0x7d, 0xbc,
+	0x36, 0x5c, 0x81, 0x98, 0x7f, 0x61, 0x61, 0x82, 0x1c, 0xb0, 0x7e, 0x04, 0x4e, 0x96, 0x5d, 0x29,
+	0x7a, 0x0d, 0xca, 0xd3, 0x88, 0x1b, 0xb1, 0x2b, 0x41, 0x12, 0x92, 0x07, 0x80, 0xcf, 0x98, 0xce,
+	0x79, 0xb2, 0x8f, 0x53, 0x16, 0x6b, 0x32, 0x84, 0xbd, 0x42, 0x36, 0x0e, 0x95, 0x8c, 0xd9, 0x1d,
+	0x4b, 0x41, 0x9a, 0x66, 0x76, 0x66, 0x86, 0x9d, 0xbd, 0x8a, 0x37, 0x39, 0x84, 0x6a, 0x56, 0x76,
+	0x7a, 0x33, 0x95, 0xb7, 0x49, 0x51, 0x62, 0x9c, 0x29, 0xda, 0x0d, 0x4c, 0x4c, 0x7e, 0x21, 0xc0,
+	0x97, 0xd3, 0x25, 0xbc, 0x77, 0xe0, 0x08, 0xeb, 0xb3, 0x25, 0xbd, 0xfd, 0x43, 0x39, 0xdf, 0x09,
+	0x72, 0x30, 0x7c, 0x61, 0x39, 0x94, 0x0c, 0xe8, 0xb3, 0x8d, 0x41, 0xcd, 0x26, 0xe7, 0x3b, 0x29,
+	0xfb, 0x4e, 0x05, 0xee, 0x0d, 0x94, 0xd4, 0x4c, 0x6a, 0xb2, 0x0f, 0x7b, 0x85, 0x3d, 0x52, 0xf5,
+	0xc9, 0x08, 0xf6, 0x4f, 0x95, 0x10, 0x7c, 0xd1, 0xad, 0xbb, 0xb6, 0xe5, 0x15, 0x1c, 0x2c, 0xce,
+	0xb1, 0xfe, 0x1f, 0x42, 0x35, 0xd6, 0x74, 0xcc, 0xe5, 0xb8, 0xa7, 0xd5, 0x2d, 0x93, 0xd6, 0xa3,
+	0x5d, 0x9b, 0x7c, 0x93, 0xe4, 0xda, 0x3f, 0x4b, 0x70, 0x90, 0x71, 0xbf, 0x4a, 0x3f, 0x5c, 0xb1,
+	0x68, 0xc6, 0x07, 0x0c, 0x7f, 0x43, 0xe0, 0xce, 0x6d, 0x86, 0x5f, 0xac, 0xff, 0xf2, 0x97, 0x7c,
+	0xad, 0xbf, 0xdc, 0xae, 0x39, 0x5d, 0xa5, 0x89, 0xf0, 0x77, 0x04, 0xf7, 0x8b, 0x7b, 0xe2, 0xd7,
+	0x6b, 0x43, 0xae, 0x34, 0xa2, 0x7e, 0xbc, 0x75, 0x7f, 0xca, 0xaa, 0xfd, 0xa3, 0x04, 0xde, 0x5f,
+	0xaa, 0x3a, 0xe2, 0x6c, 0x46, 0x27, 0x99, 0x7a, 0x5f, 0x11, 0xb8, 0x73, 0x57, 0xb9, 0x81, 0x7a,
+	0xcb, 0x17, 0xbe, 0x81, 0x7a, 0xab, 0x7e, 0x08, 0xbe, 0xa4, 0x54, 0xb6, 0x30, 0x72, 0xf9, 0xe0,
+	0xeb, 0x5b, 0x5e, 0xce, 0x11, 0xea, 0x9c, 0xc1, 0xa3, 0x7f, 0xb6, 0x16, 0x3a, 0x3b, 0x6e, 0xd6,
+	0x7a, 0x12, 0xf2, 0xeb, 0x5a, 0xe1, 0x73, 0x6f, 0xd6, 0xea, 0xff, 0x6f, 0xfe, 0xe4, 0x9e, 0xfc,
+	0x09, 0x00, 0x00, 0xff, 0xff, 0x80, 0xfd, 0xd5, 0x65, 0xff, 0x06, 0x00, 0x00,
+}

http://git-wip-us.apache.org/repos/asf/beam/blob/5fba6326/sdks/go/pkg/beam/model/org_apache_beam_fn_v1/beam_provision_api.pb.go
----------------------------------------------------------------------
diff --git a/sdks/go/pkg/beam/model/org_apache_beam_fn_v1/beam_provision_api.pb.go b/sdks/go/pkg/beam/model/org_apache_beam_fn_v1/beam_provision_api.pb.go
deleted file mode 100644
index 534f65c..0000000
--- a/sdks/go/pkg/beam/model/org_apache_beam_fn_v1/beam_provision_api.pb.go
+++ /dev/null
@@ -1,219 +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.
-
-// Code generated by protoc-gen-go. DO NOT EDIT.
-// source: beam_provision_api.proto
-
-/*
-Package org_apache_beam_fn_v1 is a generated protocol buffer package.
-
-It is generated from these files:
-	beam_provision_api.proto
-
-It has these top-level messages:
-	GetProvisionInfoRequest
-	GetProvisionInfoResponse
-	ProvisionInfo
-*/
-package org_apache_beam_fn_v1
-
-import proto "github.com/golang/protobuf/proto"
-import fmt "fmt"
-import math "math"
-import google_protobuf "github.com/golang/protobuf/ptypes/struct"
-
-import (
-	context "golang.org/x/net/context"
-	grpc "google.golang.org/grpc"
-)
-
-// Reference imports to suppress errors if they are not otherwise used.
-var _ = proto.Marshal
-var _ = fmt.Errorf
-var _ = math.Inf
-
-// This is a compile-time assertion to ensure that this generated file
-// is compatible with the proto package it is being compiled against.
-// A compilation error at this line likely means your copy of the
-// proto package needs to be updated.
-const _ = proto.ProtoPackageIsVersion2 // please upgrade the proto package
-
-// A request to get the provision info of a SDK harness worker instance.
-type GetProvisionInfoRequest struct {
-}
-
-func (m *GetProvisionInfoRequest) Reset()                    { *m = GetProvisionInfoRequest{} }
-func (m *GetProvisionInfoRequest) String() string            { return proto.CompactTextString(m) }
-func (*GetProvisionInfoRequest) ProtoMessage()               {}
-func (*GetProvisionInfoRequest) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{0} }
-
-// A response containing the provision info of a SDK harness worker instance.
-type GetProvisionInfoResponse struct {
-	Info *ProvisionInfo `protobuf:"bytes,1,opt,name=info" json:"info,omitempty"`
-}
-
-func (m *GetProvisionInfoResponse) Reset()                    { *m = GetProvisionInfoResponse{} }
-func (m *GetProvisionInfoResponse) String() string            { return proto.CompactTextString(m) }
-func (*GetProvisionInfoResponse) ProtoMessage()               {}
-func (*GetProvisionInfoResponse) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{1} }
-
-func (m *GetProvisionInfoResponse) GetInfo() *ProvisionInfo {
-	if m != nil {
-		return m.Info
-	}
-	return nil
-}
-
-// Runtime provisioning information for a SDK harness worker instance,
-// such as pipeline options, resource constraints and other job metadata
-type ProvisionInfo struct {
-	// (required) The job ID.
-	JobId string `protobuf:"bytes,1,opt,name=job_id,json=jobId" json:"job_id,omitempty"`
-	// (required) The job name.
-	JobName string `protobuf:"bytes,2,opt,name=job_name,json=jobName" json:"job_name,omitempty"`
-	// (required) Pipeline options. For non-template jobs, the options are
-	// identical to what is passed to job submission.
-	PipelineOptions *google_protobuf.Struct `protobuf:"bytes,3,opt,name=pipeline_options,json=pipelineOptions" json:"pipeline_options,omitempty"`
-}
-
-func (m *ProvisionInfo) Reset()                    { *m = ProvisionInfo{} }
-func (m *ProvisionInfo) String() string            { return proto.CompactTextString(m) }
-func (*ProvisionInfo) ProtoMessage()               {}
-func (*ProvisionInfo) Descriptor() ([]byte, []int) { return fileDescriptor0, []int{2} }
-
-func (m *ProvisionInfo) GetJobId() string {
-	if m != nil {
-		return m.JobId
-	}
-	return ""
-}
-
-func (m *ProvisionInfo) GetJobName() string {
-	if m != nil {
-		return m.JobName
-	}
-	return ""
-}
-
-func (m *ProvisionInfo) GetPipelineOptions() *google_protobuf.Struct {
-	if m != nil {
-		return m.PipelineOptions
-	}
-	return nil
-}
-
-func init() {
-	proto.RegisterType((*GetProvisionInfoRequest)(nil), "org.apache.beam.fn.v1.GetProvisionInfoRequest")
-	proto.RegisterType((*GetProvisionInfoResponse)(nil), "org.apache.beam.fn.v1.GetProvisionInfoResponse")
-	proto.RegisterType((*ProvisionInfo)(nil), "org.apache.beam.fn.v1.ProvisionInfo")
-}
-
-// Reference imports to suppress errors if they are not otherwise used.
-var _ context.Context
-var _ grpc.ClientConn
-
-// This is a compile-time assertion to ensure that this generated file
-// is compatible with the grpc package it is being compiled against.
-const _ = grpc.SupportPackageIsVersion4
-
-// Client API for ProvisionService service
-
-type ProvisionServiceClient interface {
-	// Get provision information for the SDK harness worker instance.
-	GetProvisionInfo(ctx context.Context, in *GetProvisionInfoRequest, opts ...grpc.CallOption) (*GetProvisionInfoResponse, error)
-}
-
-type provisionServiceClient struct {
-	cc *grpc.ClientConn
-}
-
-func NewProvisionServiceClient(cc *grpc.ClientConn) ProvisionServiceClient {
-	return &provisionServiceClient{cc}
-}
-
-func (c *provisionServiceClient) GetProvisionInfo(ctx context.Context, in *GetProvisionInfoRequest, opts ...grpc.CallOption) (*GetProvisionInfoResponse, error) {
-	out := new(GetProvisionInfoResponse)
-	err := grpc.Invoke(ctx, "/org.apache.beam.fn.v1.ProvisionService/GetProvisionInfo", in, out, c.cc, opts...)
-	if err != nil {
-		return nil, err
-	}
-	return out, nil
-}
-
-// Server API for ProvisionService service
-
-type ProvisionServiceServer interface {
-	// Get provision information for the SDK harness worker instance.
-	GetProvisionInfo(context.Context, *GetProvisionInfoRequest) (*GetProvisionInfoResponse, error)
-}
-
-func RegisterProvisionServiceServer(s *grpc.Server, srv ProvisionServiceServer) {
-	s.RegisterService(&_ProvisionService_serviceDesc, srv)
-}
-
-func _ProvisionService_GetProvisionInfo_Handler(srv interface{}, ctx context.Context, dec func(interface{}) error, interceptor grpc.UnaryServerInterceptor) (interface{}, error) {
-	in := new(GetProvisionInfoRequest)
-	if err := dec(in); err != nil {
-		return nil, err
-	}
-	if interceptor == nil {
-		return srv.(ProvisionServiceServer).GetProvisionInfo(ctx, in)
-	}
-	info := &grpc.UnaryServerInfo{
-		Server:     srv,
-		FullMethod: "/org.apache.beam.fn.v1.ProvisionService/GetProvisionInfo",
-	}
-	handler := func(ctx context.Context, req interface{}) (interface{}, error) {
-		return srv.(ProvisionServiceServer).GetProvisionInfo(ctx, req.(*GetProvisionInfoRequest))
-	}
-	return interceptor(ctx, in, info, handler)
-}
-
-var _ProvisionService_serviceDesc = grpc.ServiceDesc{
-	ServiceName: "org.apache.beam.fn.v1.ProvisionService",
-	HandlerType: (*ProvisionServiceServer)(nil),
-	Methods: []grpc.MethodDesc{
-		{
-			MethodName: "GetProvisionInfo",
-			Handler:    _ProvisionService_GetProvisionInfo_Handler,
-		},
-	},
-	Streams:  []grpc.StreamDesc{},
-	Metadata: "beam_provision_api.proto",
-}
-
-func init() { proto.RegisterFile("beam_provision_api.proto", fileDescriptor0) }
-
-var fileDescriptor0 = []byte{
-	// 284 bytes of a gzipped FileDescriptorProto
-	0x1f, 0x8b, 0x08, 0x00, 0x00, 0x00, 0x00, 0x00, 0x02, 0xff, 0x8c, 0x91, 0xcf, 0x4b, 0xc3, 0x30,
-	0x14, 0xc7, 0xa9, 0x3f, 0xa6, 0x46, 0xc5, 0x12, 0x18, 0xeb, 0x86, 0x07, 0x29, 0x0a, 0x9e, 0x52,
-	0x9c, 0x17, 0xaf, 0xf6, 0x22, 0xbb, 0xa8, 0x74, 0xde, 0x4b, 0xd2, 0xbd, 0xd6, 0x94, 0x35, 0x2f,
-	0x36, 0x69, 0xff, 0x03, 0xf1, 0xdf, 0x96, 0xa5, 0x74, 0x30, 0xdd, 0x60, 0xd7, 0xf7, 0x3e, 0xdf,
-	0x97, 0xf7, 0x79, 0x21, 0x81, 0x00, 0x5e, 0xa5, 0xba, 0xc6, 0x56, 0x1a, 0x89, 0x2a, 0xe5, 0x5a,
-	0x32, 0x5d, 0xa3, 0x45, 0x3a, 0xc4, 0xba, 0x60, 0x5c, 0xf3, 0xec, 0x13, 0xd8, 0x0a, 0x62, 0xb9,
-	0x62, 0xed, 0xc3, 0xe4, 0xba, 0x40, 0x2c, 0x96, 0x10, 0x39, 0x48, 0x34, 0x79, 0x64, 0x6c, 0xdd,
-	0x64, 0xb6, 0x0b, 0x85, 0x63, 0x32, 0x7a, 0x01, 0xfb, 0xde, 0x8f, 0x9b, 0xa9, 0x1c, 0x13, 0xf8,
-	0x6a, 0xc0, 0xd8, 0xf0, 0x83, 0x04, 0xff, 0x5b, 0x46, 0xa3, 0x32, 0x40, 0x9f, 0xc8, 0x91, 0x54,
-	0x39, 0x06, 0xde, 0x8d, 0x77, 0x7f, 0x3e, 0xbd, 0x65, 0x5b, 0x9f, 0x66, 0x9b, 0x59, 0x97, 0x08,
-	0xbf, 0x3d, 0x72, 0xb9, 0x51, 0xa7, 0x43, 0x32, 0x28, 0x51, 0xa4, 0x72, 0xe1, 0xa6, 0x9d, 0x25,
-	0xc7, 0x25, 0x8a, 0xd9, 0x82, 0x8e, 0xc9, 0xe9, 0xaa, 0xac, 0x78, 0x05, 0xc1, 0x81, 0x6b, 0x9c,
-	0x94, 0x28, 0x5e, 0x79, 0x05, 0x34, 0x26, 0xbe, 0x96, 0x1a, 0x96, 0x52, 0x41, 0x8a, 0xda, 0x4a,
-	0x54, 0x26, 0x38, 0x74, 0x9b, 0x8c, 0x58, 0x67, 0xcb, 0x7a, 0x5b, 0x36, 0x77, 0xb6, 0xc9, 0x55,
-	0x1f, 0x78, 0xeb, 0xf8, 0xe9, 0x8f, 0x47, 0xfc, 0xf5, 0x1e, 0x73, 0xa8, 0x5b, 0x99, 0x01, 0x35,
-	0xc4, 0xff, 0xab, 0x4c, 0xd9, 0x0e, 0xb9, 0x1d, 0x67, 0x9b, 0x44, 0x7b, 0xf3, 0xdd, 0x2d, 0xe3,
-	0x3b, 0xb2, 0xfd, 0xe7, 0xe2, 0x8b, 0x35, 0xff, 0xac, 0xa5, 0x18, 0x38, 0xa5, 0xc7, 0xdf, 0x00,
-	0x00, 0x00, 0xff, 0xff, 0x97, 0x2b, 0xbd, 0x57, 0x01, 0x02, 0x00, 0x00,
-}