replace zxq.co/ripple/hanayo
This commit is contained in:
81
vendor/google.golang.org/appengine/internal/aetesting/fake.go
generated
vendored
Normal file
81
vendor/google.golang.org/appengine/internal/aetesting/fake.go
generated
vendored
Normal file
@@ -0,0 +1,81 @@
|
||||
// Copyright 2011 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
// Package aetesting provides utilities for testing App Engine packages.
|
||||
// This is not for testing user applications.
|
||||
package aetesting
|
||||
|
||||
import (
|
||||
"fmt"
|
||||
"net/http"
|
||||
"reflect"
|
||||
"testing"
|
||||
|
||||
"github.com/golang/protobuf/proto"
|
||||
"golang.org/x/net/context"
|
||||
|
||||
"google.golang.org/appengine/internal"
|
||||
)
|
||||
|
||||
// FakeSingleContext returns a context whose Call invocations will be serviced
|
||||
// by f, which should be a function that has two arguments of the input and output
|
||||
// protocol buffer type, and one error return.
|
||||
func FakeSingleContext(t *testing.T, service, method string, f interface{}) context.Context {
|
||||
fv := reflect.ValueOf(f)
|
||||
if fv.Kind() != reflect.Func {
|
||||
t.Fatal("not a function")
|
||||
}
|
||||
ft := fv.Type()
|
||||
if ft.NumIn() != 2 || ft.NumOut() != 1 {
|
||||
t.Fatalf("f has %d in and %d out, want 2 in and 1 out", ft.NumIn(), ft.NumOut())
|
||||
}
|
||||
for i := 0; i < 2; i++ {
|
||||
at := ft.In(i)
|
||||
if !at.Implements(protoMessageType) {
|
||||
t.Fatalf("arg %d does not implement proto.Message", i)
|
||||
}
|
||||
}
|
||||
if ft.Out(0) != errorType {
|
||||
t.Fatalf("f's return is %v, want error", ft.Out(0))
|
||||
}
|
||||
s := &single{
|
||||
t: t,
|
||||
service: service,
|
||||
method: method,
|
||||
f: fv,
|
||||
}
|
||||
return internal.WithCallOverride(internal.ContextForTesting(&http.Request{}), s.call)
|
||||
}
|
||||
|
||||
var (
|
||||
protoMessageType = reflect.TypeOf((*proto.Message)(nil)).Elem()
|
||||
errorType = reflect.TypeOf((*error)(nil)).Elem()
|
||||
)
|
||||
|
||||
type single struct {
|
||||
t *testing.T
|
||||
service, method string
|
||||
f reflect.Value
|
||||
}
|
||||
|
||||
func (s *single) call(ctx context.Context, service, method string, in, out proto.Message) error {
|
||||
if service == "__go__" {
|
||||
if method == "GetNamespace" {
|
||||
return nil // always yield an empty namespace
|
||||
}
|
||||
return fmt.Errorf("Unknown API call /%s.%s", service, method)
|
||||
}
|
||||
if service != s.service || method != s.method {
|
||||
s.t.Fatalf("Unexpected call to /%s.%s", service, method)
|
||||
}
|
||||
ins := []reflect.Value{
|
||||
reflect.ValueOf(in),
|
||||
reflect.ValueOf(out),
|
||||
}
|
||||
outs := s.f.Call(ins)
|
||||
if outs[0].IsNil() {
|
||||
return nil
|
||||
}
|
||||
return outs[0].Interface().(error)
|
||||
}
|
646
vendor/google.golang.org/appengine/internal/api.go
generated
vendored
Normal file
646
vendor/google.golang.org/appengine/internal/api.go
generated
vendored
Normal file
@@ -0,0 +1,646 @@
|
||||
// Copyright 2011 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
// +build !appengine
|
||||
|
||||
package internal
|
||||
|
||||
import (
|
||||
"bytes"
|
||||
"errors"
|
||||
"fmt"
|
||||
"io/ioutil"
|
||||
"log"
|
||||
"net"
|
||||
"net/http"
|
||||
"net/url"
|
||||
"os"
|
||||
"runtime"
|
||||
"strconv"
|
||||
"strings"
|
||||
"sync"
|
||||
"sync/atomic"
|
||||
"time"
|
||||
|
||||
"github.com/golang/protobuf/proto"
|
||||
netcontext "golang.org/x/net/context"
|
||||
|
||||
basepb "google.golang.org/appengine/internal/base"
|
||||
logpb "google.golang.org/appengine/internal/log"
|
||||
remotepb "google.golang.org/appengine/internal/remote_api"
|
||||
)
|
||||
|
||||
const (
|
||||
apiPath = "/rpc_http"
|
||||
)
|
||||
|
||||
var (
|
||||
// Incoming headers.
|
||||
ticketHeader = http.CanonicalHeaderKey("X-AppEngine-API-Ticket")
|
||||
dapperHeader = http.CanonicalHeaderKey("X-Google-DapperTraceInfo")
|
||||
traceHeader = http.CanonicalHeaderKey("X-Cloud-Trace-Context")
|
||||
curNamespaceHeader = http.CanonicalHeaderKey("X-AppEngine-Current-Namespace")
|
||||
userIPHeader = http.CanonicalHeaderKey("X-AppEngine-User-IP")
|
||||
remoteAddrHeader = http.CanonicalHeaderKey("X-AppEngine-Remote-Addr")
|
||||
|
||||
// Outgoing headers.
|
||||
apiEndpointHeader = http.CanonicalHeaderKey("X-Google-RPC-Service-Endpoint")
|
||||
apiEndpointHeaderValue = []string{"app-engine-apis"}
|
||||
apiMethodHeader = http.CanonicalHeaderKey("X-Google-RPC-Service-Method")
|
||||
apiMethodHeaderValue = []string{"/VMRemoteAPI.CallRemoteAPI"}
|
||||
apiDeadlineHeader = http.CanonicalHeaderKey("X-Google-RPC-Service-Deadline")
|
||||
apiContentType = http.CanonicalHeaderKey("Content-Type")
|
||||
apiContentTypeValue = []string{"application/octet-stream"}
|
||||
logFlushHeader = http.CanonicalHeaderKey("X-AppEngine-Log-Flush-Count")
|
||||
|
||||
apiHTTPClient = &http.Client{
|
||||
Transport: &http.Transport{
|
||||
Proxy: http.ProxyFromEnvironment,
|
||||
Dial: limitDial,
|
||||
},
|
||||
}
|
||||
)
|
||||
|
||||
func apiURL() *url.URL {
|
||||
host, port := "appengine.googleapis.internal", "10001"
|
||||
if h := os.Getenv("API_HOST"); h != "" {
|
||||
host = h
|
||||
}
|
||||
if p := os.Getenv("API_PORT"); p != "" {
|
||||
port = p
|
||||
}
|
||||
return &url.URL{
|
||||
Scheme: "http",
|
||||
Host: host + ":" + port,
|
||||
Path: apiPath,
|
||||
}
|
||||
}
|
||||
|
||||
func handleHTTP(w http.ResponseWriter, r *http.Request) {
|
||||
c := &context{
|
||||
req: r,
|
||||
outHeader: w.Header(),
|
||||
apiURL: apiURL(),
|
||||
}
|
||||
stopFlushing := make(chan int)
|
||||
|
||||
ctxs.Lock()
|
||||
ctxs.m[r] = c
|
||||
ctxs.Unlock()
|
||||
defer func() {
|
||||
ctxs.Lock()
|
||||
delete(ctxs.m, r)
|
||||
ctxs.Unlock()
|
||||
}()
|
||||
|
||||
// Patch up RemoteAddr so it looks reasonable.
|
||||
if addr := r.Header.Get(userIPHeader); addr != "" {
|
||||
r.RemoteAddr = addr
|
||||
} else if addr = r.Header.Get(remoteAddrHeader); addr != "" {
|
||||
r.RemoteAddr = addr
|
||||
} else {
|
||||
// Should not normally reach here, but pick a sensible default anyway.
|
||||
r.RemoteAddr = "127.0.0.1"
|
||||
}
|
||||
// The address in the headers will most likely be of these forms:
|
||||
// 123.123.123.123
|
||||
// 2001:db8::1
|
||||
// net/http.Request.RemoteAddr is specified to be in "IP:port" form.
|
||||
if _, _, err := net.SplitHostPort(r.RemoteAddr); err != nil {
|
||||
// Assume the remote address is only a host; add a default port.
|
||||
r.RemoteAddr = net.JoinHostPort(r.RemoteAddr, "80")
|
||||
}
|
||||
|
||||
// Start goroutine responsible for flushing app logs.
|
||||
// This is done after adding c to ctx.m (and stopped before removing it)
|
||||
// because flushing logs requires making an API call.
|
||||
go c.logFlusher(stopFlushing)
|
||||
|
||||
executeRequestSafely(c, r)
|
||||
c.outHeader = nil // make sure header changes aren't respected any more
|
||||
|
||||
stopFlushing <- 1 // any logging beyond this point will be dropped
|
||||
|
||||
// Flush any pending logs asynchronously.
|
||||
c.pendingLogs.Lock()
|
||||
flushes := c.pendingLogs.flushes
|
||||
if len(c.pendingLogs.lines) > 0 {
|
||||
flushes++
|
||||
}
|
||||
c.pendingLogs.Unlock()
|
||||
go c.flushLog(false)
|
||||
w.Header().Set(logFlushHeader, strconv.Itoa(flushes))
|
||||
|
||||
// Avoid nil Write call if c.Write is never called.
|
||||
if c.outCode != 0 {
|
||||
w.WriteHeader(c.outCode)
|
||||
}
|
||||
if c.outBody != nil {
|
||||
w.Write(c.outBody)
|
||||
}
|
||||
}
|
||||
|
||||
func executeRequestSafely(c *context, r *http.Request) {
|
||||
defer func() {
|
||||
if x := recover(); x != nil {
|
||||
logf(c, 4, "%s", renderPanic(x)) // 4 == critical
|
||||
c.outCode = 500
|
||||
}
|
||||
}()
|
||||
|
||||
http.DefaultServeMux.ServeHTTP(c, r)
|
||||
}
|
||||
|
||||
func renderPanic(x interface{}) string {
|
||||
buf := make([]byte, 16<<10) // 16 KB should be plenty
|
||||
buf = buf[:runtime.Stack(buf, false)]
|
||||
|
||||
// Remove the first few stack frames:
|
||||
// this func
|
||||
// the recover closure in the caller
|
||||
// That will root the stack trace at the site of the panic.
|
||||
const (
|
||||
skipStart = "internal.renderPanic"
|
||||
skipFrames = 2
|
||||
)
|
||||
start := bytes.Index(buf, []byte(skipStart))
|
||||
p := start
|
||||
for i := 0; i < skipFrames*2 && p+1 < len(buf); i++ {
|
||||
p = bytes.IndexByte(buf[p+1:], '\n') + p + 1
|
||||
if p < 0 {
|
||||
break
|
||||
}
|
||||
}
|
||||
if p >= 0 {
|
||||
// buf[start:p+1] is the block to remove.
|
||||
// Copy buf[p+1:] over buf[start:] and shrink buf.
|
||||
copy(buf[start:], buf[p+1:])
|
||||
buf = buf[:len(buf)-(p+1-start)]
|
||||
}
|
||||
|
||||
// Add panic heading.
|
||||
head := fmt.Sprintf("panic: %v\n\n", x)
|
||||
if len(head) > len(buf) {
|
||||
// Extremely unlikely to happen.
|
||||
return head
|
||||
}
|
||||
copy(buf[len(head):], buf)
|
||||
copy(buf, head)
|
||||
|
||||
return string(buf)
|
||||
}
|
||||
|
||||
var ctxs = struct {
|
||||
sync.Mutex
|
||||
m map[*http.Request]*context
|
||||
bg *context // background context, lazily initialized
|
||||
// dec is used by tests to decorate the netcontext.Context returned
|
||||
// for a given request. This allows tests to add overrides (such as
|
||||
// WithAppIDOverride) to the context. The map is nil outside tests.
|
||||
dec map[*http.Request]func(netcontext.Context) netcontext.Context
|
||||
}{
|
||||
m: make(map[*http.Request]*context),
|
||||
}
|
||||
|
||||
// context represents the context of an in-flight HTTP request.
|
||||
// It implements the appengine.Context and http.ResponseWriter interfaces.
|
||||
type context struct {
|
||||
req *http.Request
|
||||
|
||||
outCode int
|
||||
outHeader http.Header
|
||||
outBody []byte
|
||||
|
||||
pendingLogs struct {
|
||||
sync.Mutex
|
||||
lines []*logpb.UserAppLogLine
|
||||
flushes int
|
||||
}
|
||||
|
||||
apiURL *url.URL
|
||||
}
|
||||
|
||||
var contextKey = "holds a *context"
|
||||
|
||||
func fromContext(ctx netcontext.Context) *context {
|
||||
c, _ := ctx.Value(&contextKey).(*context)
|
||||
return c
|
||||
}
|
||||
|
||||
func withContext(parent netcontext.Context, c *context) netcontext.Context {
|
||||
ctx := netcontext.WithValue(parent, &contextKey, c)
|
||||
if ns := c.req.Header.Get(curNamespaceHeader); ns != "" {
|
||||
ctx = withNamespace(ctx, ns)
|
||||
}
|
||||
return ctx
|
||||
}
|
||||
|
||||
func toContext(c *context) netcontext.Context {
|
||||
return withContext(netcontext.Background(), c)
|
||||
}
|
||||
|
||||
func IncomingHeaders(ctx netcontext.Context) http.Header {
|
||||
if c := fromContext(ctx); c != nil {
|
||||
return c.req.Header
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func WithContext(parent netcontext.Context, req *http.Request) netcontext.Context {
|
||||
ctxs.Lock()
|
||||
c := ctxs.m[req]
|
||||
d := ctxs.dec[req]
|
||||
ctxs.Unlock()
|
||||
|
||||
if d != nil {
|
||||
parent = d(parent)
|
||||
}
|
||||
|
||||
if c == nil {
|
||||
// Someone passed in an http.Request that is not in-flight.
|
||||
// We panic here rather than panicking at a later point
|
||||
// so that stack traces will be more sensible.
|
||||
log.Panic("appengine: NewContext passed an unknown http.Request")
|
||||
}
|
||||
return withContext(parent, c)
|
||||
}
|
||||
|
||||
func BackgroundContext() netcontext.Context {
|
||||
ctxs.Lock()
|
||||
defer ctxs.Unlock()
|
||||
|
||||
if ctxs.bg != nil {
|
||||
return toContext(ctxs.bg)
|
||||
}
|
||||
|
||||
// Compute background security ticket.
|
||||
appID := partitionlessAppID()
|
||||
escAppID := strings.Replace(strings.Replace(appID, ":", "_", -1), ".", "_", -1)
|
||||
majVersion := VersionID(nil)
|
||||
if i := strings.Index(majVersion, "."); i > 0 {
|
||||
majVersion = majVersion[:i]
|
||||
}
|
||||
ticket := fmt.Sprintf("%s/%s.%s.%s", escAppID, ModuleName(nil), majVersion, InstanceID())
|
||||
|
||||
ctxs.bg = &context{
|
||||
req: &http.Request{
|
||||
Header: http.Header{
|
||||
ticketHeader: []string{ticket},
|
||||
},
|
||||
},
|
||||
apiURL: apiURL(),
|
||||
}
|
||||
|
||||
// TODO(dsymonds): Wire up the shutdown handler to do a final flush.
|
||||
go ctxs.bg.logFlusher(make(chan int))
|
||||
|
||||
return toContext(ctxs.bg)
|
||||
}
|
||||
|
||||
// RegisterTestRequest registers the HTTP request req for testing, such that
|
||||
// any API calls are sent to the provided URL. It returns a closure to delete
|
||||
// the registration.
|
||||
// It should only be used by aetest package.
|
||||
func RegisterTestRequest(req *http.Request, apiURL *url.URL, decorate func(netcontext.Context) netcontext.Context) func() {
|
||||
c := &context{
|
||||
req: req,
|
||||
apiURL: apiURL,
|
||||
}
|
||||
ctxs.Lock()
|
||||
defer ctxs.Unlock()
|
||||
if _, ok := ctxs.m[req]; ok {
|
||||
log.Panic("req already associated with context")
|
||||
}
|
||||
if _, ok := ctxs.dec[req]; ok {
|
||||
log.Panic("req already associated with context")
|
||||
}
|
||||
if ctxs.dec == nil {
|
||||
ctxs.dec = make(map[*http.Request]func(netcontext.Context) netcontext.Context)
|
||||
}
|
||||
ctxs.m[req] = c
|
||||
ctxs.dec[req] = decorate
|
||||
|
||||
return func() {
|
||||
ctxs.Lock()
|
||||
delete(ctxs.m, req)
|
||||
delete(ctxs.dec, req)
|
||||
ctxs.Unlock()
|
||||
}
|
||||
}
|
||||
|
||||
var errTimeout = &CallError{
|
||||
Detail: "Deadline exceeded",
|
||||
Code: int32(remotepb.RpcError_CANCELLED),
|
||||
Timeout: true,
|
||||
}
|
||||
|
||||
func (c *context) Header() http.Header { return c.outHeader }
|
||||
|
||||
// Copied from $GOROOT/src/pkg/net/http/transfer.go. Some response status
|
||||
// codes do not permit a response body (nor response entity headers such as
|
||||
// Content-Length, Content-Type, etc).
|
||||
func bodyAllowedForStatus(status int) bool {
|
||||
switch {
|
||||
case status >= 100 && status <= 199:
|
||||
return false
|
||||
case status == 204:
|
||||
return false
|
||||
case status == 304:
|
||||
return false
|
||||
}
|
||||
return true
|
||||
}
|
||||
|
||||
func (c *context) Write(b []byte) (int, error) {
|
||||
if c.outCode == 0 {
|
||||
c.WriteHeader(http.StatusOK)
|
||||
}
|
||||
if len(b) > 0 && !bodyAllowedForStatus(c.outCode) {
|
||||
return 0, http.ErrBodyNotAllowed
|
||||
}
|
||||
c.outBody = append(c.outBody, b...)
|
||||
return len(b), nil
|
||||
}
|
||||
|
||||
func (c *context) WriteHeader(code int) {
|
||||
if c.outCode != 0 {
|
||||
logf(c, 3, "WriteHeader called multiple times on request.") // error level
|
||||
return
|
||||
}
|
||||
c.outCode = code
|
||||
}
|
||||
|
||||
func (c *context) post(body []byte, timeout time.Duration) (b []byte, err error) {
|
||||
hreq := &http.Request{
|
||||
Method: "POST",
|
||||
URL: c.apiURL,
|
||||
Header: http.Header{
|
||||
apiEndpointHeader: apiEndpointHeaderValue,
|
||||
apiMethodHeader: apiMethodHeaderValue,
|
||||
apiContentType: apiContentTypeValue,
|
||||
apiDeadlineHeader: []string{strconv.FormatFloat(timeout.Seconds(), 'f', -1, 64)},
|
||||
},
|
||||
Body: ioutil.NopCloser(bytes.NewReader(body)),
|
||||
ContentLength: int64(len(body)),
|
||||
Host: c.apiURL.Host,
|
||||
}
|
||||
if info := c.req.Header.Get(dapperHeader); info != "" {
|
||||
hreq.Header.Set(dapperHeader, info)
|
||||
}
|
||||
if info := c.req.Header.Get(traceHeader); info != "" {
|
||||
hreq.Header.Set(traceHeader, info)
|
||||
}
|
||||
|
||||
tr := apiHTTPClient.Transport.(*http.Transport)
|
||||
|
||||
var timedOut int32 // atomic; set to 1 if timed out
|
||||
t := time.AfterFunc(timeout, func() {
|
||||
atomic.StoreInt32(&timedOut, 1)
|
||||
tr.CancelRequest(hreq)
|
||||
})
|
||||
defer t.Stop()
|
||||
defer func() {
|
||||
// Check if timeout was exceeded.
|
||||
if atomic.LoadInt32(&timedOut) != 0 {
|
||||
err = errTimeout
|
||||
}
|
||||
}()
|
||||
|
||||
hresp, err := apiHTTPClient.Do(hreq)
|
||||
if err != nil {
|
||||
return nil, &CallError{
|
||||
Detail: fmt.Sprintf("service bridge HTTP failed: %v", err),
|
||||
Code: int32(remotepb.RpcError_UNKNOWN),
|
||||
}
|
||||
}
|
||||
defer hresp.Body.Close()
|
||||
hrespBody, err := ioutil.ReadAll(hresp.Body)
|
||||
if hresp.StatusCode != 200 {
|
||||
return nil, &CallError{
|
||||
Detail: fmt.Sprintf("service bridge returned HTTP %d (%q)", hresp.StatusCode, hrespBody),
|
||||
Code: int32(remotepb.RpcError_UNKNOWN),
|
||||
}
|
||||
}
|
||||
if err != nil {
|
||||
return nil, &CallError{
|
||||
Detail: fmt.Sprintf("service bridge response bad: %v", err),
|
||||
Code: int32(remotepb.RpcError_UNKNOWN),
|
||||
}
|
||||
}
|
||||
return hrespBody, nil
|
||||
}
|
||||
|
||||
func Call(ctx netcontext.Context, service, method string, in, out proto.Message) error {
|
||||
if ns := NamespaceFromContext(ctx); ns != "" {
|
||||
if fn, ok := NamespaceMods[service]; ok {
|
||||
fn(in, ns)
|
||||
}
|
||||
}
|
||||
|
||||
if f, ctx, ok := callOverrideFromContext(ctx); ok {
|
||||
return f(ctx, service, method, in, out)
|
||||
}
|
||||
|
||||
// Handle already-done contexts quickly.
|
||||
select {
|
||||
case <-ctx.Done():
|
||||
return ctx.Err()
|
||||
default:
|
||||
}
|
||||
|
||||
c := fromContext(ctx)
|
||||
if c == nil {
|
||||
// Give a good error message rather than a panic lower down.
|
||||
return errors.New("not an App Engine context")
|
||||
}
|
||||
|
||||
// Apply transaction modifications if we're in a transaction.
|
||||
if t := transactionFromContext(ctx); t != nil {
|
||||
if t.finished {
|
||||
return errors.New("transaction context has expired")
|
||||
}
|
||||
applyTransaction(in, &t.transaction)
|
||||
}
|
||||
|
||||
// Default RPC timeout is 60s.
|
||||
timeout := 60 * time.Second
|
||||
if deadline, ok := ctx.Deadline(); ok {
|
||||
timeout = deadline.Sub(time.Now())
|
||||
}
|
||||
|
||||
data, err := proto.Marshal(in)
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
|
||||
ticket := c.req.Header.Get(ticketHeader)
|
||||
req := &remotepb.Request{
|
||||
ServiceName: &service,
|
||||
Method: &method,
|
||||
Request: data,
|
||||
RequestId: &ticket,
|
||||
}
|
||||
hreqBody, err := proto.Marshal(req)
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
|
||||
hrespBody, err := c.post(hreqBody, timeout)
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
|
||||
res := &remotepb.Response{}
|
||||
if err := proto.Unmarshal(hrespBody, res); err != nil {
|
||||
return err
|
||||
}
|
||||
if res.RpcError != nil {
|
||||
ce := &CallError{
|
||||
Detail: res.RpcError.GetDetail(),
|
||||
Code: *res.RpcError.Code,
|
||||
}
|
||||
switch remotepb.RpcError_ErrorCode(ce.Code) {
|
||||
case remotepb.RpcError_CANCELLED, remotepb.RpcError_DEADLINE_EXCEEDED:
|
||||
ce.Timeout = true
|
||||
}
|
||||
return ce
|
||||
}
|
||||
if res.ApplicationError != nil {
|
||||
return &APIError{
|
||||
Service: *req.ServiceName,
|
||||
Detail: res.ApplicationError.GetDetail(),
|
||||
Code: *res.ApplicationError.Code,
|
||||
}
|
||||
}
|
||||
if res.Exception != nil || res.JavaException != nil {
|
||||
// This shouldn't happen, but let's be defensive.
|
||||
return &CallError{
|
||||
Detail: "service bridge returned exception",
|
||||
Code: int32(remotepb.RpcError_UNKNOWN),
|
||||
}
|
||||
}
|
||||
return proto.Unmarshal(res.Response, out)
|
||||
}
|
||||
|
||||
func (c *context) Request() *http.Request {
|
||||
return c.req
|
||||
}
|
||||
|
||||
func (c *context) addLogLine(ll *logpb.UserAppLogLine) {
|
||||
// Truncate long log lines.
|
||||
// TODO(dsymonds): Check if this is still necessary.
|
||||
const lim = 8 << 10
|
||||
if len(*ll.Message) > lim {
|
||||
suffix := fmt.Sprintf("...(length %d)", len(*ll.Message))
|
||||
ll.Message = proto.String((*ll.Message)[:lim-len(suffix)] + suffix)
|
||||
}
|
||||
|
||||
c.pendingLogs.Lock()
|
||||
c.pendingLogs.lines = append(c.pendingLogs.lines, ll)
|
||||
c.pendingLogs.Unlock()
|
||||
}
|
||||
|
||||
var logLevelName = map[int64]string{
|
||||
0: "DEBUG",
|
||||
1: "INFO",
|
||||
2: "WARNING",
|
||||
3: "ERROR",
|
||||
4: "CRITICAL",
|
||||
}
|
||||
|
||||
func logf(c *context, level int64, format string, args ...interface{}) {
|
||||
s := fmt.Sprintf(format, args...)
|
||||
s = strings.TrimRight(s, "\n") // Remove any trailing newline characters.
|
||||
c.addLogLine(&logpb.UserAppLogLine{
|
||||
TimestampUsec: proto.Int64(time.Now().UnixNano() / 1e3),
|
||||
Level: &level,
|
||||
Message: &s,
|
||||
})
|
||||
log.Print(logLevelName[level] + ": " + s)
|
||||
}
|
||||
|
||||
// flushLog attempts to flush any pending logs to the appserver.
|
||||
// It should not be called concurrently.
|
||||
func (c *context) flushLog(force bool) (flushed bool) {
|
||||
c.pendingLogs.Lock()
|
||||
// Grab up to 30 MB. We can get away with up to 32 MB, but let's be cautious.
|
||||
n, rem := 0, 30<<20
|
||||
for ; n < len(c.pendingLogs.lines); n++ {
|
||||
ll := c.pendingLogs.lines[n]
|
||||
// Each log line will require about 3 bytes of overhead.
|
||||
nb := proto.Size(ll) + 3
|
||||
if nb > rem {
|
||||
break
|
||||
}
|
||||
rem -= nb
|
||||
}
|
||||
lines := c.pendingLogs.lines[:n]
|
||||
c.pendingLogs.lines = c.pendingLogs.lines[n:]
|
||||
c.pendingLogs.Unlock()
|
||||
|
||||
if len(lines) == 0 && !force {
|
||||
// Nothing to flush.
|
||||
return false
|
||||
}
|
||||
|
||||
rescueLogs := false
|
||||
defer func() {
|
||||
if rescueLogs {
|
||||
c.pendingLogs.Lock()
|
||||
c.pendingLogs.lines = append(lines, c.pendingLogs.lines...)
|
||||
c.pendingLogs.Unlock()
|
||||
}
|
||||
}()
|
||||
|
||||
buf, err := proto.Marshal(&logpb.UserAppLogGroup{
|
||||
LogLine: lines,
|
||||
})
|
||||
if err != nil {
|
||||
log.Printf("internal.flushLog: marshaling UserAppLogGroup: %v", err)
|
||||
rescueLogs = true
|
||||
return false
|
||||
}
|
||||
|
||||
req := &logpb.FlushRequest{
|
||||
Logs: buf,
|
||||
}
|
||||
res := &basepb.VoidProto{}
|
||||
c.pendingLogs.Lock()
|
||||
c.pendingLogs.flushes++
|
||||
c.pendingLogs.Unlock()
|
||||
if err := Call(toContext(c), "logservice", "Flush", req, res); err != nil {
|
||||
log.Printf("internal.flushLog: Flush RPC: %v", err)
|
||||
rescueLogs = true
|
||||
return false
|
||||
}
|
||||
return true
|
||||
}
|
||||
|
||||
const (
|
||||
// Log flushing parameters.
|
||||
flushInterval = 1 * time.Second
|
||||
forceFlushInterval = 60 * time.Second
|
||||
)
|
||||
|
||||
func (c *context) logFlusher(stop <-chan int) {
|
||||
lastFlush := time.Now()
|
||||
tick := time.NewTicker(flushInterval)
|
||||
for {
|
||||
select {
|
||||
case <-stop:
|
||||
// Request finished.
|
||||
tick.Stop()
|
||||
return
|
||||
case <-tick.C:
|
||||
force := time.Now().Sub(lastFlush) > forceFlushInterval
|
||||
if c.flushLog(force) {
|
||||
lastFlush = time.Now()
|
||||
}
|
||||
}
|
||||
}
|
||||
}
|
||||
|
||||
func ContextForTesting(req *http.Request) netcontext.Context {
|
||||
return toContext(&context{req: req})
|
||||
}
|
159
vendor/google.golang.org/appengine/internal/api_classic.go
generated
vendored
Normal file
159
vendor/google.golang.org/appengine/internal/api_classic.go
generated
vendored
Normal file
@@ -0,0 +1,159 @@
|
||||
// Copyright 2015 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
// +build appengine
|
||||
|
||||
package internal
|
||||
|
||||
import (
|
||||
"errors"
|
||||
"fmt"
|
||||
"net/http"
|
||||
"time"
|
||||
|
||||
"appengine"
|
||||
"appengine_internal"
|
||||
basepb "appengine_internal/base"
|
||||
|
||||
"github.com/golang/protobuf/proto"
|
||||
netcontext "golang.org/x/net/context"
|
||||
)
|
||||
|
||||
var contextKey = "holds an appengine.Context"
|
||||
|
||||
func fromContext(ctx netcontext.Context) appengine.Context {
|
||||
c, _ := ctx.Value(&contextKey).(appengine.Context)
|
||||
return c
|
||||
}
|
||||
|
||||
// This is only for classic App Engine adapters.
|
||||
func ClassicContextFromContext(ctx netcontext.Context) appengine.Context {
|
||||
return fromContext(ctx)
|
||||
}
|
||||
|
||||
func withContext(parent netcontext.Context, c appengine.Context) netcontext.Context {
|
||||
ctx := netcontext.WithValue(parent, &contextKey, c)
|
||||
|
||||
s := &basepb.StringProto{}
|
||||
c.Call("__go__", "GetNamespace", &basepb.VoidProto{}, s, nil)
|
||||
if ns := s.GetValue(); ns != "" {
|
||||
ctx = NamespacedContext(ctx, ns)
|
||||
}
|
||||
|
||||
return ctx
|
||||
}
|
||||
|
||||
func IncomingHeaders(ctx netcontext.Context) http.Header {
|
||||
if c := fromContext(ctx); c != nil {
|
||||
if req, ok := c.Request().(*http.Request); ok {
|
||||
return req.Header
|
||||
}
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func WithContext(parent netcontext.Context, req *http.Request) netcontext.Context {
|
||||
c := appengine.NewContext(req)
|
||||
return withContext(parent, c)
|
||||
}
|
||||
|
||||
type testingContext struct {
|
||||
appengine.Context
|
||||
|
||||
req *http.Request
|
||||
}
|
||||
|
||||
func (t *testingContext) FullyQualifiedAppID() string { return "dev~testcontext" }
|
||||
func (t *testingContext) Call(service, method string, _, _ appengine_internal.ProtoMessage, _ *appengine_internal.CallOptions) error {
|
||||
if service == "__go__" && method == "GetNamespace" {
|
||||
return nil
|
||||
}
|
||||
return fmt.Errorf("testingContext: unsupported Call")
|
||||
}
|
||||
func (t *testingContext) Request() interface{} { return t.req }
|
||||
|
||||
func ContextForTesting(req *http.Request) netcontext.Context {
|
||||
return withContext(netcontext.Background(), &testingContext{req: req})
|
||||
}
|
||||
|
||||
func Call(ctx netcontext.Context, service, method string, in, out proto.Message) error {
|
||||
if ns := NamespaceFromContext(ctx); ns != "" {
|
||||
if fn, ok := NamespaceMods[service]; ok {
|
||||
fn(in, ns)
|
||||
}
|
||||
}
|
||||
|
||||
if f, ctx, ok := callOverrideFromContext(ctx); ok {
|
||||
return f(ctx, service, method, in, out)
|
||||
}
|
||||
|
||||
// Handle already-done contexts quickly.
|
||||
select {
|
||||
case <-ctx.Done():
|
||||
return ctx.Err()
|
||||
default:
|
||||
}
|
||||
|
||||
c := fromContext(ctx)
|
||||
if c == nil {
|
||||
// Give a good error message rather than a panic lower down.
|
||||
return errors.New("not an App Engine context")
|
||||
}
|
||||
|
||||
// Apply transaction modifications if we're in a transaction.
|
||||
if t := transactionFromContext(ctx); t != nil {
|
||||
if t.finished {
|
||||
return errors.New("transaction context has expired")
|
||||
}
|
||||
applyTransaction(in, &t.transaction)
|
||||
}
|
||||
|
||||
var opts *appengine_internal.CallOptions
|
||||
if d, ok := ctx.Deadline(); ok {
|
||||
opts = &appengine_internal.CallOptions{
|
||||
Timeout: d.Sub(time.Now()),
|
||||
}
|
||||
}
|
||||
|
||||
err := c.Call(service, method, in, out, opts)
|
||||
switch v := err.(type) {
|
||||
case *appengine_internal.APIError:
|
||||
return &APIError{
|
||||
Service: v.Service,
|
||||
Detail: v.Detail,
|
||||
Code: v.Code,
|
||||
}
|
||||
case *appengine_internal.CallError:
|
||||
return &CallError{
|
||||
Detail: v.Detail,
|
||||
Code: v.Code,
|
||||
Timeout: v.Timeout,
|
||||
}
|
||||
}
|
||||
return err
|
||||
}
|
||||
|
||||
func handleHTTP(w http.ResponseWriter, r *http.Request) {
|
||||
panic("handleHTTP called; this should be impossible")
|
||||
}
|
||||
|
||||
func logf(c appengine.Context, level int64, format string, args ...interface{}) {
|
||||
var fn func(format string, args ...interface{})
|
||||
switch level {
|
||||
case 0:
|
||||
fn = c.Debugf
|
||||
case 1:
|
||||
fn = c.Infof
|
||||
case 2:
|
||||
fn = c.Warningf
|
||||
case 3:
|
||||
fn = c.Errorf
|
||||
case 4:
|
||||
fn = c.Criticalf
|
||||
default:
|
||||
// This shouldn't happen.
|
||||
fn = c.Criticalf
|
||||
}
|
||||
fn(format, args...)
|
||||
}
|
86
vendor/google.golang.org/appengine/internal/api_common.go
generated
vendored
Normal file
86
vendor/google.golang.org/appengine/internal/api_common.go
generated
vendored
Normal file
@@ -0,0 +1,86 @@
|
||||
// Copyright 2015 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
package internal
|
||||
|
||||
import (
|
||||
"github.com/golang/protobuf/proto"
|
||||
netcontext "golang.org/x/net/context"
|
||||
)
|
||||
|
||||
type CallOverrideFunc func(ctx netcontext.Context, service, method string, in, out proto.Message) error
|
||||
|
||||
var callOverrideKey = "holds []CallOverrideFunc"
|
||||
|
||||
func WithCallOverride(ctx netcontext.Context, f CallOverrideFunc) netcontext.Context {
|
||||
// We avoid appending to any existing call override
|
||||
// so we don't risk overwriting a popped stack below.
|
||||
var cofs []CallOverrideFunc
|
||||
if uf, ok := ctx.Value(&callOverrideKey).([]CallOverrideFunc); ok {
|
||||
cofs = append(cofs, uf...)
|
||||
}
|
||||
cofs = append(cofs, f)
|
||||
return netcontext.WithValue(ctx, &callOverrideKey, cofs)
|
||||
}
|
||||
|
||||
func callOverrideFromContext(ctx netcontext.Context) (CallOverrideFunc, netcontext.Context, bool) {
|
||||
cofs, _ := ctx.Value(&callOverrideKey).([]CallOverrideFunc)
|
||||
if len(cofs) == 0 {
|
||||
return nil, nil, false
|
||||
}
|
||||
// We found a list of overrides; grab the last, and reconstitute a
|
||||
// context that will hide it.
|
||||
f := cofs[len(cofs)-1]
|
||||
ctx = netcontext.WithValue(ctx, &callOverrideKey, cofs[:len(cofs)-1])
|
||||
return f, ctx, true
|
||||
}
|
||||
|
||||
type logOverrideFunc func(level int64, format string, args ...interface{})
|
||||
|
||||
var logOverrideKey = "holds a logOverrideFunc"
|
||||
|
||||
func WithLogOverride(ctx netcontext.Context, f logOverrideFunc) netcontext.Context {
|
||||
return netcontext.WithValue(ctx, &logOverrideKey, f)
|
||||
}
|
||||
|
||||
var appIDOverrideKey = "holds a string, being the full app ID"
|
||||
|
||||
func WithAppIDOverride(ctx netcontext.Context, appID string) netcontext.Context {
|
||||
return netcontext.WithValue(ctx, &appIDOverrideKey, appID)
|
||||
}
|
||||
|
||||
var namespaceKey = "holds the namespace string"
|
||||
|
||||
func withNamespace(ctx netcontext.Context, ns string) netcontext.Context {
|
||||
return netcontext.WithValue(ctx, &namespaceKey, ns)
|
||||
}
|
||||
|
||||
func NamespaceFromContext(ctx netcontext.Context) string {
|
||||
// If there's no namespace, return the empty string.
|
||||
ns, _ := ctx.Value(&namespaceKey).(string)
|
||||
return ns
|
||||
}
|
||||
|
||||
// FullyQualifiedAppID returns the fully-qualified application ID.
|
||||
// This may contain a partition prefix (e.g. "s~" for High Replication apps),
|
||||
// or a domain prefix (e.g. "example.com:").
|
||||
func FullyQualifiedAppID(ctx netcontext.Context) string {
|
||||
if id, ok := ctx.Value(&appIDOverrideKey).(string); ok {
|
||||
return id
|
||||
}
|
||||
return fullyQualifiedAppID(ctx)
|
||||
}
|
||||
|
||||
func Logf(ctx netcontext.Context, level int64, format string, args ...interface{}) {
|
||||
if f, ok := ctx.Value(&logOverrideKey).(logOverrideFunc); ok {
|
||||
f(level, format, args...)
|
||||
return
|
||||
}
|
||||
logf(fromContext(ctx), level, format, args...)
|
||||
}
|
||||
|
||||
// NamespacedContext wraps a Context to support namespaces.
|
||||
func NamespacedContext(ctx netcontext.Context, namespace string) netcontext.Context {
|
||||
return withNamespace(ctx, namespace)
|
||||
}
|
9
vendor/google.golang.org/appengine/internal/api_race_test.go
generated
vendored
Normal file
9
vendor/google.golang.org/appengine/internal/api_race_test.go
generated
vendored
Normal file
@@ -0,0 +1,9 @@
|
||||
// Copyright 2014 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
// +build race
|
||||
|
||||
package internal
|
||||
|
||||
func init() { raceDetector = true }
|
467
vendor/google.golang.org/appengine/internal/api_test.go
generated
vendored
Normal file
467
vendor/google.golang.org/appengine/internal/api_test.go
generated
vendored
Normal file
@@ -0,0 +1,467 @@
|
||||
// Copyright 2014 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
// +build !appengine
|
||||
|
||||
package internal
|
||||
|
||||
import (
|
||||
"bufio"
|
||||
"bytes"
|
||||
"fmt"
|
||||
"io"
|
||||
"io/ioutil"
|
||||
"net/http"
|
||||
"net/http/httptest"
|
||||
"net/url"
|
||||
"os"
|
||||
"os/exec"
|
||||
"strings"
|
||||
"sync/atomic"
|
||||
"testing"
|
||||
"time"
|
||||
|
||||
"github.com/golang/protobuf/proto"
|
||||
netcontext "golang.org/x/net/context"
|
||||
|
||||
basepb "google.golang.org/appengine/internal/base"
|
||||
remotepb "google.golang.org/appengine/internal/remote_api"
|
||||
)
|
||||
|
||||
const testTicketHeader = "X-Magic-Ticket-Header"
|
||||
|
||||
func init() {
|
||||
ticketHeader = testTicketHeader
|
||||
}
|
||||
|
||||
type fakeAPIHandler struct {
|
||||
hang chan int // used for RunSlowly RPC
|
||||
|
||||
LogFlushes int32 // atomic
|
||||
}
|
||||
|
||||
func (f *fakeAPIHandler) ServeHTTP(w http.ResponseWriter, r *http.Request) {
|
||||
writeResponse := func(res *remotepb.Response) {
|
||||
hresBody, err := proto.Marshal(res)
|
||||
if err != nil {
|
||||
http.Error(w, fmt.Sprintf("Failed encoding API response: %v", err), 500)
|
||||
return
|
||||
}
|
||||
w.Write(hresBody)
|
||||
}
|
||||
|
||||
if r.URL.Path != "/rpc_http" {
|
||||
http.NotFound(w, r)
|
||||
return
|
||||
}
|
||||
hreqBody, err := ioutil.ReadAll(r.Body)
|
||||
if err != nil {
|
||||
http.Error(w, fmt.Sprintf("Bad body: %v", err), 500)
|
||||
return
|
||||
}
|
||||
apiReq := &remotepb.Request{}
|
||||
if err := proto.Unmarshal(hreqBody, apiReq); err != nil {
|
||||
http.Error(w, fmt.Sprintf("Bad encoded API request: %v", err), 500)
|
||||
return
|
||||
}
|
||||
if *apiReq.RequestId != "s3cr3t" {
|
||||
writeResponse(&remotepb.Response{
|
||||
RpcError: &remotepb.RpcError{
|
||||
Code: proto.Int32(int32(remotepb.RpcError_SECURITY_VIOLATION)),
|
||||
Detail: proto.String("bad security ticket"),
|
||||
},
|
||||
})
|
||||
return
|
||||
}
|
||||
if got, want := r.Header.Get(dapperHeader), "trace-001"; got != want {
|
||||
writeResponse(&remotepb.Response{
|
||||
RpcError: &remotepb.RpcError{
|
||||
Code: proto.Int32(int32(remotepb.RpcError_BAD_REQUEST)),
|
||||
Detail: proto.String(fmt.Sprintf("trace info = %q, want %q", got, want)),
|
||||
},
|
||||
})
|
||||
return
|
||||
}
|
||||
|
||||
service, method := *apiReq.ServiceName, *apiReq.Method
|
||||
var resOut proto.Message
|
||||
if service == "actordb" && method == "LookupActor" {
|
||||
req := &basepb.StringProto{}
|
||||
res := &basepb.StringProto{}
|
||||
if err := proto.Unmarshal(apiReq.Request, req); err != nil {
|
||||
http.Error(w, fmt.Sprintf("Bad encoded request: %v", err), 500)
|
||||
return
|
||||
}
|
||||
if *req.Value == "Doctor Who" {
|
||||
res.Value = proto.String("David Tennant")
|
||||
}
|
||||
resOut = res
|
||||
}
|
||||
if service == "errors" {
|
||||
switch method {
|
||||
case "Non200":
|
||||
http.Error(w, "I'm a little teapot.", 418)
|
||||
return
|
||||
case "ShortResponse":
|
||||
w.Header().Set("Content-Length", "100")
|
||||
w.Write([]byte("way too short"))
|
||||
return
|
||||
case "OverQuota":
|
||||
writeResponse(&remotepb.Response{
|
||||
RpcError: &remotepb.RpcError{
|
||||
Code: proto.Int32(int32(remotepb.RpcError_OVER_QUOTA)),
|
||||
Detail: proto.String("you are hogging the resources!"),
|
||||
},
|
||||
})
|
||||
return
|
||||
case "RunSlowly":
|
||||
// TestAPICallRPCFailure creates f.hang, but does not strobe it
|
||||
// until Call returns with remotepb.RpcError_CANCELLED.
|
||||
// This is here to force a happens-before relationship between
|
||||
// the httptest server handler and shutdown.
|
||||
<-f.hang
|
||||
resOut = &basepb.VoidProto{}
|
||||
}
|
||||
}
|
||||
if service == "logservice" && method == "Flush" {
|
||||
// Pretend log flushing is slow.
|
||||
time.Sleep(50 * time.Millisecond)
|
||||
atomic.AddInt32(&f.LogFlushes, 1)
|
||||
resOut = &basepb.VoidProto{}
|
||||
}
|
||||
|
||||
encOut, err := proto.Marshal(resOut)
|
||||
if err != nil {
|
||||
http.Error(w, fmt.Sprintf("Failed encoding response: %v", err), 500)
|
||||
return
|
||||
}
|
||||
writeResponse(&remotepb.Response{
|
||||
Response: encOut,
|
||||
})
|
||||
}
|
||||
|
||||
func setup() (f *fakeAPIHandler, c *context, cleanup func()) {
|
||||
f = &fakeAPIHandler{}
|
||||
srv := httptest.NewServer(f)
|
||||
u, err := url.Parse(srv.URL + apiPath)
|
||||
if err != nil {
|
||||
panic(fmt.Sprintf("url.Parse(%q): %v", srv.URL+apiPath, err))
|
||||
}
|
||||
return f, &context{
|
||||
req: &http.Request{
|
||||
Header: http.Header{
|
||||
ticketHeader: []string{"s3cr3t"},
|
||||
dapperHeader: []string{"trace-001"},
|
||||
},
|
||||
},
|
||||
apiURL: u,
|
||||
}, srv.Close
|
||||
}
|
||||
|
||||
func TestAPICall(t *testing.T) {
|
||||
_, c, cleanup := setup()
|
||||
defer cleanup()
|
||||
|
||||
req := &basepb.StringProto{
|
||||
Value: proto.String("Doctor Who"),
|
||||
}
|
||||
res := &basepb.StringProto{}
|
||||
err := Call(toContext(c), "actordb", "LookupActor", req, res)
|
||||
if err != nil {
|
||||
t.Fatalf("API call failed: %v", err)
|
||||
}
|
||||
if got, want := *res.Value, "David Tennant"; got != want {
|
||||
t.Errorf("Response is %q, want %q", got, want)
|
||||
}
|
||||
}
|
||||
|
||||
func TestAPICallRPCFailure(t *testing.T) {
|
||||
f, c, cleanup := setup()
|
||||
defer cleanup()
|
||||
|
||||
testCases := []struct {
|
||||
method string
|
||||
code remotepb.RpcError_ErrorCode
|
||||
}{
|
||||
{"Non200", remotepb.RpcError_UNKNOWN},
|
||||
{"ShortResponse", remotepb.RpcError_UNKNOWN},
|
||||
{"OverQuota", remotepb.RpcError_OVER_QUOTA},
|
||||
{"RunSlowly", remotepb.RpcError_CANCELLED},
|
||||
}
|
||||
f.hang = make(chan int) // only for RunSlowly
|
||||
for _, tc := range testCases {
|
||||
ctx, _ := netcontext.WithTimeout(toContext(c), 100*time.Millisecond)
|
||||
err := Call(ctx, "errors", tc.method, &basepb.VoidProto{}, &basepb.VoidProto{})
|
||||
ce, ok := err.(*CallError)
|
||||
if !ok {
|
||||
t.Errorf("%s: API call error is %T (%v), want *CallError", tc.method, err, err)
|
||||
continue
|
||||
}
|
||||
if ce.Code != int32(tc.code) {
|
||||
t.Errorf("%s: ce.Code = %d, want %d", tc.method, ce.Code, tc.code)
|
||||
}
|
||||
if tc.method == "RunSlowly" {
|
||||
f.hang <- 1 // release the HTTP handler
|
||||
}
|
||||
}
|
||||
}
|
||||
|
||||
func TestAPICallDialFailure(t *testing.T) {
|
||||
// See what happens if the API host is unresponsive.
|
||||
// This should time out quickly, not hang forever.
|
||||
_, c, cleanup := setup()
|
||||
defer cleanup()
|
||||
// Reset the URL to the production address so that dialing fails.
|
||||
c.apiURL = apiURL()
|
||||
|
||||
start := time.Now()
|
||||
err := Call(toContext(c), "foo", "bar", &basepb.VoidProto{}, &basepb.VoidProto{})
|
||||
const max = 1 * time.Second
|
||||
if taken := time.Since(start); taken > max {
|
||||
t.Errorf("Dial hang took too long: %v > %v", taken, max)
|
||||
}
|
||||
if err == nil {
|
||||
t.Error("Call did not fail")
|
||||
}
|
||||
}
|
||||
|
||||
func TestDelayedLogFlushing(t *testing.T) {
|
||||
f, c, cleanup := setup()
|
||||
defer cleanup()
|
||||
|
||||
http.HandleFunc("/quick_log", func(w http.ResponseWriter, r *http.Request) {
|
||||
logC := WithContext(netcontext.Background(), r)
|
||||
fromContext(logC).apiURL = c.apiURL // Otherwise it will try to use the default URL.
|
||||
Logf(logC, 1, "It's a lovely day.")
|
||||
w.WriteHeader(200)
|
||||
w.Write(make([]byte, 100<<10)) // write 100 KB to force HTTP flush
|
||||
})
|
||||
|
||||
r := &http.Request{
|
||||
Method: "GET",
|
||||
URL: &url.URL{
|
||||
Scheme: "http",
|
||||
Path: "/quick_log",
|
||||
},
|
||||
Header: c.req.Header,
|
||||
Body: ioutil.NopCloser(bytes.NewReader(nil)),
|
||||
}
|
||||
w := httptest.NewRecorder()
|
||||
|
||||
// Check that log flushing does not hold up the HTTP response.
|
||||
start := time.Now()
|
||||
handleHTTP(w, r)
|
||||
if d := time.Since(start); d > 10*time.Millisecond {
|
||||
t.Errorf("handleHTTP took %v, want under 10ms", d)
|
||||
}
|
||||
const hdr = "X-AppEngine-Log-Flush-Count"
|
||||
if h := w.HeaderMap.Get(hdr); h != "1" {
|
||||
t.Errorf("%s header = %q, want %q", hdr, h, "1")
|
||||
}
|
||||
if f := atomic.LoadInt32(&f.LogFlushes); f != 0 {
|
||||
t.Errorf("After HTTP response: f.LogFlushes = %d, want 0", f)
|
||||
}
|
||||
|
||||
// Check that the log flush eventually comes in.
|
||||
time.Sleep(100 * time.Millisecond)
|
||||
if f := atomic.LoadInt32(&f.LogFlushes); f != 1 {
|
||||
t.Errorf("After 100ms: f.LogFlushes = %d, want 1", f)
|
||||
}
|
||||
}
|
||||
|
||||
func TestRemoteAddr(t *testing.T) {
|
||||
var addr string
|
||||
http.HandleFunc("/remote_addr", func(w http.ResponseWriter, r *http.Request) {
|
||||
addr = r.RemoteAddr
|
||||
})
|
||||
|
||||
testCases := []struct {
|
||||
headers http.Header
|
||||
addr string
|
||||
}{
|
||||
{http.Header{"X-Appengine-User-Ip": []string{"10.5.2.1"}}, "10.5.2.1:80"},
|
||||
{http.Header{"X-Appengine-Remote-Addr": []string{"1.2.3.4"}}, "1.2.3.4:80"},
|
||||
{http.Header{"X-Appengine-Remote-Addr": []string{"1.2.3.4:8080"}}, "1.2.3.4:8080"},
|
||||
{
|
||||
http.Header{"X-Appengine-Remote-Addr": []string{"2401:fa00:9:1:7646:a0ff:fe90:ca66"}},
|
||||
"[2401:fa00:9:1:7646:a0ff:fe90:ca66]:80",
|
||||
},
|
||||
{
|
||||
http.Header{"X-Appengine-Remote-Addr": []string{"[::1]:http"}},
|
||||
"[::1]:http",
|
||||
},
|
||||
{http.Header{}, "127.0.0.1:80"},
|
||||
}
|
||||
|
||||
for _, tc := range testCases {
|
||||
r := &http.Request{
|
||||
Method: "GET",
|
||||
URL: &url.URL{Scheme: "http", Path: "/remote_addr"},
|
||||
Header: tc.headers,
|
||||
Body: ioutil.NopCloser(bytes.NewReader(nil)),
|
||||
}
|
||||
handleHTTP(httptest.NewRecorder(), r)
|
||||
if addr != tc.addr {
|
||||
t.Errorf("Header %v, got %q, want %q", tc.headers, addr, tc.addr)
|
||||
}
|
||||
}
|
||||
}
|
||||
|
||||
func TestPanickingHandler(t *testing.T) {
|
||||
http.HandleFunc("/panic", func(http.ResponseWriter, *http.Request) {
|
||||
panic("whoops!")
|
||||
})
|
||||
r := &http.Request{
|
||||
Method: "GET",
|
||||
URL: &url.URL{Scheme: "http", Path: "/panic"},
|
||||
Body: ioutil.NopCloser(bytes.NewReader(nil)),
|
||||
}
|
||||
rec := httptest.NewRecorder()
|
||||
handleHTTP(rec, r)
|
||||
if rec.Code != 500 {
|
||||
t.Errorf("Panicking handler returned HTTP %d, want HTTP %d", rec.Code, 500)
|
||||
}
|
||||
}
|
||||
|
||||
var raceDetector = false
|
||||
|
||||
func TestAPICallAllocations(t *testing.T) {
|
||||
if raceDetector {
|
||||
t.Skip("not running under race detector")
|
||||
}
|
||||
|
||||
// Run the test API server in a subprocess so we aren't counting its allocations.
|
||||
u, cleanup := launchHelperProcess(t)
|
||||
defer cleanup()
|
||||
c := &context{
|
||||
req: &http.Request{
|
||||
Header: http.Header{
|
||||
ticketHeader: []string{"s3cr3t"},
|
||||
dapperHeader: []string{"trace-001"},
|
||||
},
|
||||
},
|
||||
apiURL: u,
|
||||
}
|
||||
|
||||
req := &basepb.StringProto{
|
||||
Value: proto.String("Doctor Who"),
|
||||
}
|
||||
res := &basepb.StringProto{}
|
||||
var apiErr error
|
||||
avg := testing.AllocsPerRun(100, func() {
|
||||
ctx, _ := netcontext.WithTimeout(toContext(c), 100*time.Millisecond)
|
||||
if err := Call(ctx, "actordb", "LookupActor", req, res); err != nil && apiErr == nil {
|
||||
apiErr = err // get the first error only
|
||||
}
|
||||
})
|
||||
if apiErr != nil {
|
||||
t.Errorf("API call failed: %v", apiErr)
|
||||
}
|
||||
|
||||
// Lots of room for improvement...
|
||||
// TODO(djd): Reduce maximum to 85 once the App Engine SDK is based on 1.6.
|
||||
const min, max float64 = 70, 90
|
||||
if avg < min || max < avg {
|
||||
t.Errorf("Allocations per API call = %g, want in [%g,%g]", avg, min, max)
|
||||
}
|
||||
}
|
||||
|
||||
func launchHelperProcess(t *testing.T) (apiURL *url.URL, cleanup func()) {
|
||||
cmd := exec.Command(os.Args[0], "-test.run=TestHelperProcess")
|
||||
cmd.Env = []string{"GO_WANT_HELPER_PROCESS=1"}
|
||||
stdin, err := cmd.StdinPipe()
|
||||
if err != nil {
|
||||
t.Fatalf("StdinPipe: %v", err)
|
||||
}
|
||||
stdout, err := cmd.StdoutPipe()
|
||||
if err != nil {
|
||||
t.Fatalf("StdoutPipe: %v", err)
|
||||
}
|
||||
if err := cmd.Start(); err != nil {
|
||||
t.Fatalf("Starting helper process: %v", err)
|
||||
}
|
||||
|
||||
scan := bufio.NewScanner(stdout)
|
||||
var u *url.URL
|
||||
for scan.Scan() {
|
||||
line := scan.Text()
|
||||
if hp := strings.TrimPrefix(line, helperProcessMagic); hp != line {
|
||||
var err error
|
||||
u, err = url.Parse(hp)
|
||||
if err != nil {
|
||||
t.Fatalf("Failed to parse %q: %v", hp, err)
|
||||
}
|
||||
break
|
||||
}
|
||||
}
|
||||
if err := scan.Err(); err != nil {
|
||||
t.Fatalf("Scanning helper process stdout: %v", err)
|
||||
}
|
||||
if u == nil {
|
||||
t.Fatal("Helper process never reported")
|
||||
}
|
||||
|
||||
return u, func() {
|
||||
stdin.Close()
|
||||
if err := cmd.Wait(); err != nil {
|
||||
t.Errorf("Helper process did not exit cleanly: %v", err)
|
||||
}
|
||||
}
|
||||
}
|
||||
|
||||
const helperProcessMagic = "A lovely helper process is listening at "
|
||||
|
||||
// This isn't a real test. It's used as a helper process.
|
||||
func TestHelperProcess(*testing.T) {
|
||||
if os.Getenv("GO_WANT_HELPER_PROCESS") != "1" {
|
||||
return
|
||||
}
|
||||
defer os.Exit(0)
|
||||
|
||||
f := &fakeAPIHandler{}
|
||||
srv := httptest.NewServer(f)
|
||||
defer srv.Close()
|
||||
fmt.Println(helperProcessMagic + srv.URL + apiPath)
|
||||
|
||||
// Wait for stdin to be closed.
|
||||
io.Copy(ioutil.Discard, os.Stdin)
|
||||
}
|
||||
|
||||
func TestBackgroundContext(t *testing.T) {
|
||||
environ := []struct {
|
||||
key, value string
|
||||
}{
|
||||
{"GAE_LONG_APP_ID", "my-app-id"},
|
||||
{"GAE_MINOR_VERSION", "067924799508853122"},
|
||||
{"GAE_MODULE_INSTANCE", "0"},
|
||||
{"GAE_MODULE_NAME", "default"},
|
||||
{"GAE_MODULE_VERSION", "20150612t184001"},
|
||||
}
|
||||
for _, v := range environ {
|
||||
old := os.Getenv(v.key)
|
||||
os.Setenv(v.key, v.value)
|
||||
v.value = old
|
||||
}
|
||||
defer func() { // Restore old environment after the test completes.
|
||||
for _, v := range environ {
|
||||
if v.value == "" {
|
||||
os.Unsetenv(v.key)
|
||||
continue
|
||||
}
|
||||
os.Setenv(v.key, v.value)
|
||||
}
|
||||
}()
|
||||
|
||||
ctx, key := fromContext(BackgroundContext()), "X-Magic-Ticket-Header"
|
||||
if g, w := ctx.req.Header.Get(key), "my-app-id/default.20150612t184001.0"; g != w {
|
||||
t.Errorf("%v = %q, want %q", key, g, w)
|
||||
}
|
||||
|
||||
// Check that using the background context doesn't panic.
|
||||
req := &basepb.StringProto{
|
||||
Value: proto.String("Doctor Who"),
|
||||
}
|
||||
res := &basepb.StringProto{}
|
||||
Call(BackgroundContext(), "actordb", "LookupActor", req, res) // expected to fail
|
||||
}
|
28
vendor/google.golang.org/appengine/internal/app_id.go
generated
vendored
Normal file
28
vendor/google.golang.org/appengine/internal/app_id.go
generated
vendored
Normal file
@@ -0,0 +1,28 @@
|
||||
// Copyright 2011 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
package internal
|
||||
|
||||
import (
|
||||
"strings"
|
||||
)
|
||||
|
||||
func parseFullAppID(appid string) (partition, domain, displayID string) {
|
||||
if i := strings.Index(appid, "~"); i != -1 {
|
||||
partition, appid = appid[:i], appid[i+1:]
|
||||
}
|
||||
if i := strings.Index(appid, ":"); i != -1 {
|
||||
domain, appid = appid[:i], appid[i+1:]
|
||||
}
|
||||
return partition, domain, appid
|
||||
}
|
||||
|
||||
// appID returns "appid" or "domain.com:appid".
|
||||
func appID(fullAppID string) string {
|
||||
_, dom, dis := parseFullAppID(fullAppID)
|
||||
if dom != "" {
|
||||
return dom + ":" + dis
|
||||
}
|
||||
return dis
|
||||
}
|
34
vendor/google.golang.org/appengine/internal/app_id_test.go
generated
vendored
Normal file
34
vendor/google.golang.org/appengine/internal/app_id_test.go
generated
vendored
Normal file
@@ -0,0 +1,34 @@
|
||||
// Copyright 2011 Google Inc. All Rights Reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
package internal
|
||||
|
||||
import (
|
||||
"testing"
|
||||
)
|
||||
|
||||
func TestAppIDParsing(t *testing.T) {
|
||||
testCases := []struct {
|
||||
in string
|
||||
partition, domain, displayID string
|
||||
}{
|
||||
{"simple-app-id", "", "", "simple-app-id"},
|
||||
{"domain.com:domain-app-id", "", "domain.com", "domain-app-id"},
|
||||
{"part~partition-app-id", "part", "", "partition-app-id"},
|
||||
{"part~domain.com:display", "part", "domain.com", "display"},
|
||||
}
|
||||
|
||||
for _, tc := range testCases {
|
||||
part, dom, dis := parseFullAppID(tc.in)
|
||||
if part != tc.partition {
|
||||
t.Errorf("partition of %q: got %q, want %q", tc.in, part, tc.partition)
|
||||
}
|
||||
if dom != tc.domain {
|
||||
t.Errorf("domain of %q: got %q, want %q", tc.in, dom, tc.domain)
|
||||
}
|
||||
if dis != tc.displayID {
|
||||
t.Errorf("displayID of %q: got %q, want %q", tc.in, dis, tc.displayID)
|
||||
}
|
||||
}
|
||||
}
|
296
vendor/google.golang.org/appengine/internal/app_identity/app_identity_service.pb.go
generated
vendored
Normal file
296
vendor/google.golang.org/appengine/internal/app_identity/app_identity_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,296 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/app_identity/app_identity_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package app_identity is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/app_identity/app_identity_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
AppIdentityServiceError
|
||||
SignForAppRequest
|
||||
SignForAppResponse
|
||||
GetPublicCertificateForAppRequest
|
||||
PublicCertificate
|
||||
GetPublicCertificateForAppResponse
|
||||
GetServiceAccountNameRequest
|
||||
GetServiceAccountNameResponse
|
||||
GetAccessTokenRequest
|
||||
GetAccessTokenResponse
|
||||
GetDefaultGcsBucketNameRequest
|
||||
GetDefaultGcsBucketNameResponse
|
||||
*/
|
||||
package app_identity
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type AppIdentityServiceError_ErrorCode int32
|
||||
|
||||
const (
|
||||
AppIdentityServiceError_SUCCESS AppIdentityServiceError_ErrorCode = 0
|
||||
AppIdentityServiceError_UNKNOWN_SCOPE AppIdentityServiceError_ErrorCode = 9
|
||||
AppIdentityServiceError_BLOB_TOO_LARGE AppIdentityServiceError_ErrorCode = 1000
|
||||
AppIdentityServiceError_DEADLINE_EXCEEDED AppIdentityServiceError_ErrorCode = 1001
|
||||
AppIdentityServiceError_NOT_A_VALID_APP AppIdentityServiceError_ErrorCode = 1002
|
||||
AppIdentityServiceError_UNKNOWN_ERROR AppIdentityServiceError_ErrorCode = 1003
|
||||
AppIdentityServiceError_NOT_ALLOWED AppIdentityServiceError_ErrorCode = 1005
|
||||
AppIdentityServiceError_NOT_IMPLEMENTED AppIdentityServiceError_ErrorCode = 1006
|
||||
)
|
||||
|
||||
var AppIdentityServiceError_ErrorCode_name = map[int32]string{
|
||||
0: "SUCCESS",
|
||||
9: "UNKNOWN_SCOPE",
|
||||
1000: "BLOB_TOO_LARGE",
|
||||
1001: "DEADLINE_EXCEEDED",
|
||||
1002: "NOT_A_VALID_APP",
|
||||
1003: "UNKNOWN_ERROR",
|
||||
1005: "NOT_ALLOWED",
|
||||
1006: "NOT_IMPLEMENTED",
|
||||
}
|
||||
var AppIdentityServiceError_ErrorCode_value = map[string]int32{
|
||||
"SUCCESS": 0,
|
||||
"UNKNOWN_SCOPE": 9,
|
||||
"BLOB_TOO_LARGE": 1000,
|
||||
"DEADLINE_EXCEEDED": 1001,
|
||||
"NOT_A_VALID_APP": 1002,
|
||||
"UNKNOWN_ERROR": 1003,
|
||||
"NOT_ALLOWED": 1005,
|
||||
"NOT_IMPLEMENTED": 1006,
|
||||
}
|
||||
|
||||
func (x AppIdentityServiceError_ErrorCode) Enum() *AppIdentityServiceError_ErrorCode {
|
||||
p := new(AppIdentityServiceError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x AppIdentityServiceError_ErrorCode) String() string {
|
||||
return proto.EnumName(AppIdentityServiceError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *AppIdentityServiceError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(AppIdentityServiceError_ErrorCode_value, data, "AppIdentityServiceError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = AppIdentityServiceError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type AppIdentityServiceError struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *AppIdentityServiceError) Reset() { *m = AppIdentityServiceError{} }
|
||||
func (m *AppIdentityServiceError) String() string { return proto.CompactTextString(m) }
|
||||
func (*AppIdentityServiceError) ProtoMessage() {}
|
||||
|
||||
type SignForAppRequest struct {
|
||||
BytesToSign []byte `protobuf:"bytes,1,opt,name=bytes_to_sign" json:"bytes_to_sign,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *SignForAppRequest) Reset() { *m = SignForAppRequest{} }
|
||||
func (m *SignForAppRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*SignForAppRequest) ProtoMessage() {}
|
||||
|
||||
func (m *SignForAppRequest) GetBytesToSign() []byte {
|
||||
if m != nil {
|
||||
return m.BytesToSign
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type SignForAppResponse struct {
|
||||
KeyName *string `protobuf:"bytes,1,opt,name=key_name" json:"key_name,omitempty"`
|
||||
SignatureBytes []byte `protobuf:"bytes,2,opt,name=signature_bytes" json:"signature_bytes,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *SignForAppResponse) Reset() { *m = SignForAppResponse{} }
|
||||
func (m *SignForAppResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*SignForAppResponse) ProtoMessage() {}
|
||||
|
||||
func (m *SignForAppResponse) GetKeyName() string {
|
||||
if m != nil && m.KeyName != nil {
|
||||
return *m.KeyName
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *SignForAppResponse) GetSignatureBytes() []byte {
|
||||
if m != nil {
|
||||
return m.SignatureBytes
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type GetPublicCertificateForAppRequest struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetPublicCertificateForAppRequest) Reset() { *m = GetPublicCertificateForAppRequest{} }
|
||||
func (m *GetPublicCertificateForAppRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetPublicCertificateForAppRequest) ProtoMessage() {}
|
||||
|
||||
type PublicCertificate struct {
|
||||
KeyName *string `protobuf:"bytes,1,opt,name=key_name" json:"key_name,omitempty"`
|
||||
X509CertificatePem *string `protobuf:"bytes,2,opt,name=x509_certificate_pem" json:"x509_certificate_pem,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *PublicCertificate) Reset() { *m = PublicCertificate{} }
|
||||
func (m *PublicCertificate) String() string { return proto.CompactTextString(m) }
|
||||
func (*PublicCertificate) ProtoMessage() {}
|
||||
|
||||
func (m *PublicCertificate) GetKeyName() string {
|
||||
if m != nil && m.KeyName != nil {
|
||||
return *m.KeyName
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *PublicCertificate) GetX509CertificatePem() string {
|
||||
if m != nil && m.X509CertificatePem != nil {
|
||||
return *m.X509CertificatePem
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type GetPublicCertificateForAppResponse struct {
|
||||
PublicCertificateList []*PublicCertificate `protobuf:"bytes,1,rep,name=public_certificate_list" json:"public_certificate_list,omitempty"`
|
||||
MaxClientCacheTimeInSecond *int64 `protobuf:"varint,2,opt,name=max_client_cache_time_in_second" json:"max_client_cache_time_in_second,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetPublicCertificateForAppResponse) Reset() { *m = GetPublicCertificateForAppResponse{} }
|
||||
func (m *GetPublicCertificateForAppResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetPublicCertificateForAppResponse) ProtoMessage() {}
|
||||
|
||||
func (m *GetPublicCertificateForAppResponse) GetPublicCertificateList() []*PublicCertificate {
|
||||
if m != nil {
|
||||
return m.PublicCertificateList
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *GetPublicCertificateForAppResponse) GetMaxClientCacheTimeInSecond() int64 {
|
||||
if m != nil && m.MaxClientCacheTimeInSecond != nil {
|
||||
return *m.MaxClientCacheTimeInSecond
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type GetServiceAccountNameRequest struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetServiceAccountNameRequest) Reset() { *m = GetServiceAccountNameRequest{} }
|
||||
func (m *GetServiceAccountNameRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetServiceAccountNameRequest) ProtoMessage() {}
|
||||
|
||||
type GetServiceAccountNameResponse struct {
|
||||
ServiceAccountName *string `protobuf:"bytes,1,opt,name=service_account_name" json:"service_account_name,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetServiceAccountNameResponse) Reset() { *m = GetServiceAccountNameResponse{} }
|
||||
func (m *GetServiceAccountNameResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetServiceAccountNameResponse) ProtoMessage() {}
|
||||
|
||||
func (m *GetServiceAccountNameResponse) GetServiceAccountName() string {
|
||||
if m != nil && m.ServiceAccountName != nil {
|
||||
return *m.ServiceAccountName
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type GetAccessTokenRequest struct {
|
||||
Scope []string `protobuf:"bytes,1,rep,name=scope" json:"scope,omitempty"`
|
||||
ServiceAccountId *int64 `protobuf:"varint,2,opt,name=service_account_id" json:"service_account_id,omitempty"`
|
||||
ServiceAccountName *string `protobuf:"bytes,3,opt,name=service_account_name" json:"service_account_name,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetAccessTokenRequest) Reset() { *m = GetAccessTokenRequest{} }
|
||||
func (m *GetAccessTokenRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetAccessTokenRequest) ProtoMessage() {}
|
||||
|
||||
func (m *GetAccessTokenRequest) GetScope() []string {
|
||||
if m != nil {
|
||||
return m.Scope
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *GetAccessTokenRequest) GetServiceAccountId() int64 {
|
||||
if m != nil && m.ServiceAccountId != nil {
|
||||
return *m.ServiceAccountId
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *GetAccessTokenRequest) GetServiceAccountName() string {
|
||||
if m != nil && m.ServiceAccountName != nil {
|
||||
return *m.ServiceAccountName
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type GetAccessTokenResponse struct {
|
||||
AccessToken *string `protobuf:"bytes,1,opt,name=access_token" json:"access_token,omitempty"`
|
||||
ExpirationTime *int64 `protobuf:"varint,2,opt,name=expiration_time" json:"expiration_time,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetAccessTokenResponse) Reset() { *m = GetAccessTokenResponse{} }
|
||||
func (m *GetAccessTokenResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetAccessTokenResponse) ProtoMessage() {}
|
||||
|
||||
func (m *GetAccessTokenResponse) GetAccessToken() string {
|
||||
if m != nil && m.AccessToken != nil {
|
||||
return *m.AccessToken
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *GetAccessTokenResponse) GetExpirationTime() int64 {
|
||||
if m != nil && m.ExpirationTime != nil {
|
||||
return *m.ExpirationTime
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type GetDefaultGcsBucketNameRequest struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetDefaultGcsBucketNameRequest) Reset() { *m = GetDefaultGcsBucketNameRequest{} }
|
||||
func (m *GetDefaultGcsBucketNameRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetDefaultGcsBucketNameRequest) ProtoMessage() {}
|
||||
|
||||
type GetDefaultGcsBucketNameResponse struct {
|
||||
DefaultGcsBucketName *string `protobuf:"bytes,1,opt,name=default_gcs_bucket_name" json:"default_gcs_bucket_name,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetDefaultGcsBucketNameResponse) Reset() { *m = GetDefaultGcsBucketNameResponse{} }
|
||||
func (m *GetDefaultGcsBucketNameResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetDefaultGcsBucketNameResponse) ProtoMessage() {}
|
||||
|
||||
func (m *GetDefaultGcsBucketNameResponse) GetDefaultGcsBucketName() string {
|
||||
if m != nil && m.DefaultGcsBucketName != nil {
|
||||
return *m.DefaultGcsBucketName
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func init() {
|
||||
}
|
64
vendor/google.golang.org/appengine/internal/app_identity/app_identity_service.proto
generated
vendored
Normal file
64
vendor/google.golang.org/appengine/internal/app_identity/app_identity_service.proto
generated
vendored
Normal file
@@ -0,0 +1,64 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "app_identity";
|
||||
|
||||
package appengine;
|
||||
|
||||
message AppIdentityServiceError {
|
||||
enum ErrorCode {
|
||||
SUCCESS = 0;
|
||||
UNKNOWN_SCOPE = 9;
|
||||
BLOB_TOO_LARGE = 1000;
|
||||
DEADLINE_EXCEEDED = 1001;
|
||||
NOT_A_VALID_APP = 1002;
|
||||
UNKNOWN_ERROR = 1003;
|
||||
NOT_ALLOWED = 1005;
|
||||
NOT_IMPLEMENTED = 1006;
|
||||
}
|
||||
}
|
||||
|
||||
message SignForAppRequest {
|
||||
optional bytes bytes_to_sign = 1;
|
||||
}
|
||||
|
||||
message SignForAppResponse {
|
||||
optional string key_name = 1;
|
||||
optional bytes signature_bytes = 2;
|
||||
}
|
||||
|
||||
message GetPublicCertificateForAppRequest {
|
||||
}
|
||||
|
||||
message PublicCertificate {
|
||||
optional string key_name = 1;
|
||||
optional string x509_certificate_pem = 2;
|
||||
}
|
||||
|
||||
message GetPublicCertificateForAppResponse {
|
||||
repeated PublicCertificate public_certificate_list = 1;
|
||||
optional int64 max_client_cache_time_in_second = 2;
|
||||
}
|
||||
|
||||
message GetServiceAccountNameRequest {
|
||||
}
|
||||
|
||||
message GetServiceAccountNameResponse {
|
||||
optional string service_account_name = 1;
|
||||
}
|
||||
|
||||
message GetAccessTokenRequest {
|
||||
repeated string scope = 1;
|
||||
optional int64 service_account_id = 2;
|
||||
optional string service_account_name = 3;
|
||||
}
|
||||
|
||||
message GetAccessTokenResponse {
|
||||
optional string access_token = 1;
|
||||
optional int64 expiration_time = 2;
|
||||
}
|
||||
|
||||
message GetDefaultGcsBucketNameRequest {
|
||||
}
|
||||
|
||||
message GetDefaultGcsBucketNameResponse {
|
||||
optional string default_gcs_bucket_name = 1;
|
||||
}
|
133
vendor/google.golang.org/appengine/internal/base/api_base.pb.go
generated
vendored
Normal file
133
vendor/google.golang.org/appengine/internal/base/api_base.pb.go
generated
vendored
Normal file
@@ -0,0 +1,133 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/base/api_base.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package base is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/base/api_base.proto
|
||||
|
||||
It has these top-level messages:
|
||||
StringProto
|
||||
Integer32Proto
|
||||
Integer64Proto
|
||||
BoolProto
|
||||
DoubleProto
|
||||
BytesProto
|
||||
VoidProto
|
||||
*/
|
||||
package base
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type StringProto struct {
|
||||
Value *string `protobuf:"bytes,1,req,name=value" json:"value,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *StringProto) Reset() { *m = StringProto{} }
|
||||
func (m *StringProto) String() string { return proto.CompactTextString(m) }
|
||||
func (*StringProto) ProtoMessage() {}
|
||||
|
||||
func (m *StringProto) GetValue() string {
|
||||
if m != nil && m.Value != nil {
|
||||
return *m.Value
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type Integer32Proto struct {
|
||||
Value *int32 `protobuf:"varint,1,req,name=value" json:"value,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *Integer32Proto) Reset() { *m = Integer32Proto{} }
|
||||
func (m *Integer32Proto) String() string { return proto.CompactTextString(m) }
|
||||
func (*Integer32Proto) ProtoMessage() {}
|
||||
|
||||
func (m *Integer32Proto) GetValue() int32 {
|
||||
if m != nil && m.Value != nil {
|
||||
return *m.Value
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type Integer64Proto struct {
|
||||
Value *int64 `protobuf:"varint,1,req,name=value" json:"value,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *Integer64Proto) Reset() { *m = Integer64Proto{} }
|
||||
func (m *Integer64Proto) String() string { return proto.CompactTextString(m) }
|
||||
func (*Integer64Proto) ProtoMessage() {}
|
||||
|
||||
func (m *Integer64Proto) GetValue() int64 {
|
||||
if m != nil && m.Value != nil {
|
||||
return *m.Value
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type BoolProto struct {
|
||||
Value *bool `protobuf:"varint,1,req,name=value" json:"value,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *BoolProto) Reset() { *m = BoolProto{} }
|
||||
func (m *BoolProto) String() string { return proto.CompactTextString(m) }
|
||||
func (*BoolProto) ProtoMessage() {}
|
||||
|
||||
func (m *BoolProto) GetValue() bool {
|
||||
if m != nil && m.Value != nil {
|
||||
return *m.Value
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
type DoubleProto struct {
|
||||
Value *float64 `protobuf:"fixed64,1,req,name=value" json:"value,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *DoubleProto) Reset() { *m = DoubleProto{} }
|
||||
func (m *DoubleProto) String() string { return proto.CompactTextString(m) }
|
||||
func (*DoubleProto) ProtoMessage() {}
|
||||
|
||||
func (m *DoubleProto) GetValue() float64 {
|
||||
if m != nil && m.Value != nil {
|
||||
return *m.Value
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type BytesProto struct {
|
||||
Value []byte `protobuf:"bytes,1,req,name=value" json:"value,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *BytesProto) Reset() { *m = BytesProto{} }
|
||||
func (m *BytesProto) String() string { return proto.CompactTextString(m) }
|
||||
func (*BytesProto) ProtoMessage() {}
|
||||
|
||||
func (m *BytesProto) GetValue() []byte {
|
||||
if m != nil {
|
||||
return m.Value
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type VoidProto struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *VoidProto) Reset() { *m = VoidProto{} }
|
||||
func (m *VoidProto) String() string { return proto.CompactTextString(m) }
|
||||
func (*VoidProto) ProtoMessage() {}
|
33
vendor/google.golang.org/appengine/internal/base/api_base.proto
generated
vendored
Normal file
33
vendor/google.golang.org/appengine/internal/base/api_base.proto
generated
vendored
Normal file
@@ -0,0 +1,33 @@
|
||||
// Built-in base types for API calls. Primarily useful as return types.
|
||||
|
||||
syntax = "proto2";
|
||||
option go_package = "base";
|
||||
|
||||
package appengine.base;
|
||||
|
||||
message StringProto {
|
||||
required string value = 1;
|
||||
}
|
||||
|
||||
message Integer32Proto {
|
||||
required int32 value = 1;
|
||||
}
|
||||
|
||||
message Integer64Proto {
|
||||
required int64 value = 1;
|
||||
}
|
||||
|
||||
message BoolProto {
|
||||
required bool value = 1;
|
||||
}
|
||||
|
||||
message DoubleProto {
|
||||
required double value = 1;
|
||||
}
|
||||
|
||||
message BytesProto {
|
||||
required bytes value = 1 [ctype=CORD];
|
||||
}
|
||||
|
||||
message VoidProto {
|
||||
}
|
347
vendor/google.golang.org/appengine/internal/blobstore/blobstore_service.pb.go
generated
vendored
Normal file
347
vendor/google.golang.org/appengine/internal/blobstore/blobstore_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,347 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/blobstore/blobstore_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package blobstore is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/blobstore/blobstore_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
BlobstoreServiceError
|
||||
CreateUploadURLRequest
|
||||
CreateUploadURLResponse
|
||||
DeleteBlobRequest
|
||||
FetchDataRequest
|
||||
FetchDataResponse
|
||||
CloneBlobRequest
|
||||
CloneBlobResponse
|
||||
DecodeBlobKeyRequest
|
||||
DecodeBlobKeyResponse
|
||||
CreateEncodedGoogleStorageKeyRequest
|
||||
CreateEncodedGoogleStorageKeyResponse
|
||||
*/
|
||||
package blobstore
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type BlobstoreServiceError_ErrorCode int32
|
||||
|
||||
const (
|
||||
BlobstoreServiceError_OK BlobstoreServiceError_ErrorCode = 0
|
||||
BlobstoreServiceError_INTERNAL_ERROR BlobstoreServiceError_ErrorCode = 1
|
||||
BlobstoreServiceError_URL_TOO_LONG BlobstoreServiceError_ErrorCode = 2
|
||||
BlobstoreServiceError_PERMISSION_DENIED BlobstoreServiceError_ErrorCode = 3
|
||||
BlobstoreServiceError_BLOB_NOT_FOUND BlobstoreServiceError_ErrorCode = 4
|
||||
BlobstoreServiceError_DATA_INDEX_OUT_OF_RANGE BlobstoreServiceError_ErrorCode = 5
|
||||
BlobstoreServiceError_BLOB_FETCH_SIZE_TOO_LARGE BlobstoreServiceError_ErrorCode = 6
|
||||
BlobstoreServiceError_ARGUMENT_OUT_OF_RANGE BlobstoreServiceError_ErrorCode = 8
|
||||
BlobstoreServiceError_INVALID_BLOB_KEY BlobstoreServiceError_ErrorCode = 9
|
||||
)
|
||||
|
||||
var BlobstoreServiceError_ErrorCode_name = map[int32]string{
|
||||
0: "OK",
|
||||
1: "INTERNAL_ERROR",
|
||||
2: "URL_TOO_LONG",
|
||||
3: "PERMISSION_DENIED",
|
||||
4: "BLOB_NOT_FOUND",
|
||||
5: "DATA_INDEX_OUT_OF_RANGE",
|
||||
6: "BLOB_FETCH_SIZE_TOO_LARGE",
|
||||
8: "ARGUMENT_OUT_OF_RANGE",
|
||||
9: "INVALID_BLOB_KEY",
|
||||
}
|
||||
var BlobstoreServiceError_ErrorCode_value = map[string]int32{
|
||||
"OK": 0,
|
||||
"INTERNAL_ERROR": 1,
|
||||
"URL_TOO_LONG": 2,
|
||||
"PERMISSION_DENIED": 3,
|
||||
"BLOB_NOT_FOUND": 4,
|
||||
"DATA_INDEX_OUT_OF_RANGE": 5,
|
||||
"BLOB_FETCH_SIZE_TOO_LARGE": 6,
|
||||
"ARGUMENT_OUT_OF_RANGE": 8,
|
||||
"INVALID_BLOB_KEY": 9,
|
||||
}
|
||||
|
||||
func (x BlobstoreServiceError_ErrorCode) Enum() *BlobstoreServiceError_ErrorCode {
|
||||
p := new(BlobstoreServiceError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x BlobstoreServiceError_ErrorCode) String() string {
|
||||
return proto.EnumName(BlobstoreServiceError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *BlobstoreServiceError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(BlobstoreServiceError_ErrorCode_value, data, "BlobstoreServiceError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = BlobstoreServiceError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type BlobstoreServiceError struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *BlobstoreServiceError) Reset() { *m = BlobstoreServiceError{} }
|
||||
func (m *BlobstoreServiceError) String() string { return proto.CompactTextString(m) }
|
||||
func (*BlobstoreServiceError) ProtoMessage() {}
|
||||
|
||||
type CreateUploadURLRequest struct {
|
||||
SuccessPath *string `protobuf:"bytes,1,req,name=success_path" json:"success_path,omitempty"`
|
||||
MaxUploadSizeBytes *int64 `protobuf:"varint,2,opt,name=max_upload_size_bytes" json:"max_upload_size_bytes,omitempty"`
|
||||
MaxUploadSizePerBlobBytes *int64 `protobuf:"varint,3,opt,name=max_upload_size_per_blob_bytes" json:"max_upload_size_per_blob_bytes,omitempty"`
|
||||
GsBucketName *string `protobuf:"bytes,4,opt,name=gs_bucket_name" json:"gs_bucket_name,omitempty"`
|
||||
UrlExpiryTimeSeconds *int32 `protobuf:"varint,5,opt,name=url_expiry_time_seconds" json:"url_expiry_time_seconds,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CreateUploadURLRequest) Reset() { *m = CreateUploadURLRequest{} }
|
||||
func (m *CreateUploadURLRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*CreateUploadURLRequest) ProtoMessage() {}
|
||||
|
||||
func (m *CreateUploadURLRequest) GetSuccessPath() string {
|
||||
if m != nil && m.SuccessPath != nil {
|
||||
return *m.SuccessPath
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *CreateUploadURLRequest) GetMaxUploadSizeBytes() int64 {
|
||||
if m != nil && m.MaxUploadSizeBytes != nil {
|
||||
return *m.MaxUploadSizeBytes
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *CreateUploadURLRequest) GetMaxUploadSizePerBlobBytes() int64 {
|
||||
if m != nil && m.MaxUploadSizePerBlobBytes != nil {
|
||||
return *m.MaxUploadSizePerBlobBytes
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *CreateUploadURLRequest) GetGsBucketName() string {
|
||||
if m != nil && m.GsBucketName != nil {
|
||||
return *m.GsBucketName
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *CreateUploadURLRequest) GetUrlExpiryTimeSeconds() int32 {
|
||||
if m != nil && m.UrlExpiryTimeSeconds != nil {
|
||||
return *m.UrlExpiryTimeSeconds
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type CreateUploadURLResponse struct {
|
||||
Url *string `protobuf:"bytes,1,req,name=url" json:"url,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CreateUploadURLResponse) Reset() { *m = CreateUploadURLResponse{} }
|
||||
func (m *CreateUploadURLResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*CreateUploadURLResponse) ProtoMessage() {}
|
||||
|
||||
func (m *CreateUploadURLResponse) GetUrl() string {
|
||||
if m != nil && m.Url != nil {
|
||||
return *m.Url
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type DeleteBlobRequest struct {
|
||||
BlobKey []string `protobuf:"bytes,1,rep,name=blob_key" json:"blob_key,omitempty"`
|
||||
Token *string `protobuf:"bytes,2,opt,name=token" json:"token,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *DeleteBlobRequest) Reset() { *m = DeleteBlobRequest{} }
|
||||
func (m *DeleteBlobRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*DeleteBlobRequest) ProtoMessage() {}
|
||||
|
||||
func (m *DeleteBlobRequest) GetBlobKey() []string {
|
||||
if m != nil {
|
||||
return m.BlobKey
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *DeleteBlobRequest) GetToken() string {
|
||||
if m != nil && m.Token != nil {
|
||||
return *m.Token
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type FetchDataRequest struct {
|
||||
BlobKey *string `protobuf:"bytes,1,req,name=blob_key" json:"blob_key,omitempty"`
|
||||
StartIndex *int64 `protobuf:"varint,2,req,name=start_index" json:"start_index,omitempty"`
|
||||
EndIndex *int64 `protobuf:"varint,3,req,name=end_index" json:"end_index,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *FetchDataRequest) Reset() { *m = FetchDataRequest{} }
|
||||
func (m *FetchDataRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*FetchDataRequest) ProtoMessage() {}
|
||||
|
||||
func (m *FetchDataRequest) GetBlobKey() string {
|
||||
if m != nil && m.BlobKey != nil {
|
||||
return *m.BlobKey
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *FetchDataRequest) GetStartIndex() int64 {
|
||||
if m != nil && m.StartIndex != nil {
|
||||
return *m.StartIndex
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *FetchDataRequest) GetEndIndex() int64 {
|
||||
if m != nil && m.EndIndex != nil {
|
||||
return *m.EndIndex
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type FetchDataResponse struct {
|
||||
Data []byte `protobuf:"bytes,1000,req,name=data" json:"data,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *FetchDataResponse) Reset() { *m = FetchDataResponse{} }
|
||||
func (m *FetchDataResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*FetchDataResponse) ProtoMessage() {}
|
||||
|
||||
func (m *FetchDataResponse) GetData() []byte {
|
||||
if m != nil {
|
||||
return m.Data
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type CloneBlobRequest struct {
|
||||
BlobKey []byte `protobuf:"bytes,1,req,name=blob_key" json:"blob_key,omitempty"`
|
||||
MimeType []byte `protobuf:"bytes,2,req,name=mime_type" json:"mime_type,omitempty"`
|
||||
TargetAppId []byte `protobuf:"bytes,3,req,name=target_app_id" json:"target_app_id,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CloneBlobRequest) Reset() { *m = CloneBlobRequest{} }
|
||||
func (m *CloneBlobRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*CloneBlobRequest) ProtoMessage() {}
|
||||
|
||||
func (m *CloneBlobRequest) GetBlobKey() []byte {
|
||||
if m != nil {
|
||||
return m.BlobKey
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *CloneBlobRequest) GetMimeType() []byte {
|
||||
if m != nil {
|
||||
return m.MimeType
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *CloneBlobRequest) GetTargetAppId() []byte {
|
||||
if m != nil {
|
||||
return m.TargetAppId
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type CloneBlobResponse struct {
|
||||
BlobKey []byte `protobuf:"bytes,1,req,name=blob_key" json:"blob_key,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CloneBlobResponse) Reset() { *m = CloneBlobResponse{} }
|
||||
func (m *CloneBlobResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*CloneBlobResponse) ProtoMessage() {}
|
||||
|
||||
func (m *CloneBlobResponse) GetBlobKey() []byte {
|
||||
if m != nil {
|
||||
return m.BlobKey
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type DecodeBlobKeyRequest struct {
|
||||
BlobKey []string `protobuf:"bytes,1,rep,name=blob_key" json:"blob_key,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *DecodeBlobKeyRequest) Reset() { *m = DecodeBlobKeyRequest{} }
|
||||
func (m *DecodeBlobKeyRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*DecodeBlobKeyRequest) ProtoMessage() {}
|
||||
|
||||
func (m *DecodeBlobKeyRequest) GetBlobKey() []string {
|
||||
if m != nil {
|
||||
return m.BlobKey
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type DecodeBlobKeyResponse struct {
|
||||
Decoded []string `protobuf:"bytes,1,rep,name=decoded" json:"decoded,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *DecodeBlobKeyResponse) Reset() { *m = DecodeBlobKeyResponse{} }
|
||||
func (m *DecodeBlobKeyResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*DecodeBlobKeyResponse) ProtoMessage() {}
|
||||
|
||||
func (m *DecodeBlobKeyResponse) GetDecoded() []string {
|
||||
if m != nil {
|
||||
return m.Decoded
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type CreateEncodedGoogleStorageKeyRequest struct {
|
||||
Filename *string `protobuf:"bytes,1,req,name=filename" json:"filename,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CreateEncodedGoogleStorageKeyRequest) Reset() { *m = CreateEncodedGoogleStorageKeyRequest{} }
|
||||
func (m *CreateEncodedGoogleStorageKeyRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*CreateEncodedGoogleStorageKeyRequest) ProtoMessage() {}
|
||||
|
||||
func (m *CreateEncodedGoogleStorageKeyRequest) GetFilename() string {
|
||||
if m != nil && m.Filename != nil {
|
||||
return *m.Filename
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type CreateEncodedGoogleStorageKeyResponse struct {
|
||||
BlobKey *string `protobuf:"bytes,1,req,name=blob_key" json:"blob_key,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CreateEncodedGoogleStorageKeyResponse) Reset() { *m = CreateEncodedGoogleStorageKeyResponse{} }
|
||||
func (m *CreateEncodedGoogleStorageKeyResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*CreateEncodedGoogleStorageKeyResponse) ProtoMessage() {}
|
||||
|
||||
func (m *CreateEncodedGoogleStorageKeyResponse) GetBlobKey() string {
|
||||
if m != nil && m.BlobKey != nil {
|
||||
return *m.BlobKey
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func init() {
|
||||
}
|
71
vendor/google.golang.org/appengine/internal/blobstore/blobstore_service.proto
generated
vendored
Normal file
71
vendor/google.golang.org/appengine/internal/blobstore/blobstore_service.proto
generated
vendored
Normal file
@@ -0,0 +1,71 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "blobstore";
|
||||
|
||||
package appengine;
|
||||
|
||||
message BlobstoreServiceError {
|
||||
enum ErrorCode {
|
||||
OK = 0;
|
||||
INTERNAL_ERROR = 1;
|
||||
URL_TOO_LONG = 2;
|
||||
PERMISSION_DENIED = 3;
|
||||
BLOB_NOT_FOUND = 4;
|
||||
DATA_INDEX_OUT_OF_RANGE = 5;
|
||||
BLOB_FETCH_SIZE_TOO_LARGE = 6;
|
||||
ARGUMENT_OUT_OF_RANGE = 8;
|
||||
INVALID_BLOB_KEY = 9;
|
||||
}
|
||||
}
|
||||
|
||||
message CreateUploadURLRequest {
|
||||
required string success_path = 1;
|
||||
optional int64 max_upload_size_bytes = 2;
|
||||
optional int64 max_upload_size_per_blob_bytes = 3;
|
||||
optional string gs_bucket_name = 4;
|
||||
optional int32 url_expiry_time_seconds = 5;
|
||||
}
|
||||
|
||||
message CreateUploadURLResponse {
|
||||
required string url = 1;
|
||||
}
|
||||
|
||||
message DeleteBlobRequest {
|
||||
repeated string blob_key = 1;
|
||||
optional string token = 2;
|
||||
}
|
||||
|
||||
message FetchDataRequest {
|
||||
required string blob_key = 1;
|
||||
required int64 start_index = 2;
|
||||
required int64 end_index = 3;
|
||||
}
|
||||
|
||||
message FetchDataResponse {
|
||||
required bytes data = 1000 [ctype = CORD];
|
||||
}
|
||||
|
||||
message CloneBlobRequest {
|
||||
required bytes blob_key = 1;
|
||||
required bytes mime_type = 2;
|
||||
required bytes target_app_id = 3;
|
||||
}
|
||||
|
||||
message CloneBlobResponse {
|
||||
required bytes blob_key = 1;
|
||||
}
|
||||
|
||||
message DecodeBlobKeyRequest {
|
||||
repeated string blob_key = 1;
|
||||
}
|
||||
|
||||
message DecodeBlobKeyResponse {
|
||||
repeated string decoded = 1;
|
||||
}
|
||||
|
||||
message CreateEncodedGoogleStorageKeyRequest {
|
||||
required string filename = 1;
|
||||
}
|
||||
|
||||
message CreateEncodedGoogleStorageKeyResponse {
|
||||
required string blob_key = 1;
|
||||
}
|
125
vendor/google.golang.org/appengine/internal/capability/capability_service.pb.go
generated
vendored
Normal file
125
vendor/google.golang.org/appengine/internal/capability/capability_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,125 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/capability/capability_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package capability is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/capability/capability_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
IsEnabledRequest
|
||||
IsEnabledResponse
|
||||
*/
|
||||
package capability
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type IsEnabledResponse_SummaryStatus int32
|
||||
|
||||
const (
|
||||
IsEnabledResponse_DEFAULT IsEnabledResponse_SummaryStatus = 0
|
||||
IsEnabledResponse_ENABLED IsEnabledResponse_SummaryStatus = 1
|
||||
IsEnabledResponse_SCHEDULED_FUTURE IsEnabledResponse_SummaryStatus = 2
|
||||
IsEnabledResponse_SCHEDULED_NOW IsEnabledResponse_SummaryStatus = 3
|
||||
IsEnabledResponse_DISABLED IsEnabledResponse_SummaryStatus = 4
|
||||
IsEnabledResponse_UNKNOWN IsEnabledResponse_SummaryStatus = 5
|
||||
)
|
||||
|
||||
var IsEnabledResponse_SummaryStatus_name = map[int32]string{
|
||||
0: "DEFAULT",
|
||||
1: "ENABLED",
|
||||
2: "SCHEDULED_FUTURE",
|
||||
3: "SCHEDULED_NOW",
|
||||
4: "DISABLED",
|
||||
5: "UNKNOWN",
|
||||
}
|
||||
var IsEnabledResponse_SummaryStatus_value = map[string]int32{
|
||||
"DEFAULT": 0,
|
||||
"ENABLED": 1,
|
||||
"SCHEDULED_FUTURE": 2,
|
||||
"SCHEDULED_NOW": 3,
|
||||
"DISABLED": 4,
|
||||
"UNKNOWN": 5,
|
||||
}
|
||||
|
||||
func (x IsEnabledResponse_SummaryStatus) Enum() *IsEnabledResponse_SummaryStatus {
|
||||
p := new(IsEnabledResponse_SummaryStatus)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x IsEnabledResponse_SummaryStatus) String() string {
|
||||
return proto.EnumName(IsEnabledResponse_SummaryStatus_name, int32(x))
|
||||
}
|
||||
func (x *IsEnabledResponse_SummaryStatus) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(IsEnabledResponse_SummaryStatus_value, data, "IsEnabledResponse_SummaryStatus")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = IsEnabledResponse_SummaryStatus(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type IsEnabledRequest struct {
|
||||
Package *string `protobuf:"bytes,1,req,name=package" json:"package,omitempty"`
|
||||
Capability []string `protobuf:"bytes,2,rep,name=capability" json:"capability,omitempty"`
|
||||
Call []string `protobuf:"bytes,3,rep,name=call" json:"call,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *IsEnabledRequest) Reset() { *m = IsEnabledRequest{} }
|
||||
func (m *IsEnabledRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*IsEnabledRequest) ProtoMessage() {}
|
||||
|
||||
func (m *IsEnabledRequest) GetPackage() string {
|
||||
if m != nil && m.Package != nil {
|
||||
return *m.Package
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *IsEnabledRequest) GetCapability() []string {
|
||||
if m != nil {
|
||||
return m.Capability
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *IsEnabledRequest) GetCall() []string {
|
||||
if m != nil {
|
||||
return m.Call
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type IsEnabledResponse struct {
|
||||
SummaryStatus *IsEnabledResponse_SummaryStatus `protobuf:"varint,1,opt,name=summary_status,enum=appengine.IsEnabledResponse_SummaryStatus" json:"summary_status,omitempty"`
|
||||
TimeUntilScheduled *int64 `protobuf:"varint,2,opt,name=time_until_scheduled" json:"time_until_scheduled,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *IsEnabledResponse) Reset() { *m = IsEnabledResponse{} }
|
||||
func (m *IsEnabledResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*IsEnabledResponse) ProtoMessage() {}
|
||||
|
||||
func (m *IsEnabledResponse) GetSummaryStatus() IsEnabledResponse_SummaryStatus {
|
||||
if m != nil && m.SummaryStatus != nil {
|
||||
return *m.SummaryStatus
|
||||
}
|
||||
return IsEnabledResponse_DEFAULT
|
||||
}
|
||||
|
||||
func (m *IsEnabledResponse) GetTimeUntilScheduled() int64 {
|
||||
if m != nil && m.TimeUntilScheduled != nil {
|
||||
return *m.TimeUntilScheduled
|
||||
}
|
||||
return 0
|
||||
}
|
28
vendor/google.golang.org/appengine/internal/capability/capability_service.proto
generated
vendored
Normal file
28
vendor/google.golang.org/appengine/internal/capability/capability_service.proto
generated
vendored
Normal file
@@ -0,0 +1,28 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "capability";
|
||||
|
||||
package appengine;
|
||||
|
||||
message IsEnabledRequest {
|
||||
required string package = 1;
|
||||
repeated string capability = 2;
|
||||
repeated string call = 3;
|
||||
}
|
||||
|
||||
message IsEnabledResponse {
|
||||
enum SummaryStatus {
|
||||
DEFAULT = 0;
|
||||
ENABLED = 1;
|
||||
SCHEDULED_FUTURE = 2;
|
||||
SCHEDULED_NOW = 3;
|
||||
DISABLED = 4;
|
||||
UNKNOWN = 5;
|
||||
}
|
||||
optional SummaryStatus summary_status = 1;
|
||||
|
||||
optional int64 time_until_scheduled = 2;
|
||||
}
|
||||
|
||||
service CapabilityService {
|
||||
rpc IsEnabled(IsEnabledRequest) returns (IsEnabledResponse) {};
|
||||
}
|
154
vendor/google.golang.org/appengine/internal/channel/channel_service.pb.go
generated
vendored
Normal file
154
vendor/google.golang.org/appengine/internal/channel/channel_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,154 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/channel/channel_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package channel is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/channel/channel_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
ChannelServiceError
|
||||
CreateChannelRequest
|
||||
CreateChannelResponse
|
||||
SendMessageRequest
|
||||
*/
|
||||
package channel
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type ChannelServiceError_ErrorCode int32
|
||||
|
||||
const (
|
||||
ChannelServiceError_OK ChannelServiceError_ErrorCode = 0
|
||||
ChannelServiceError_INTERNAL_ERROR ChannelServiceError_ErrorCode = 1
|
||||
ChannelServiceError_INVALID_CHANNEL_KEY ChannelServiceError_ErrorCode = 2
|
||||
ChannelServiceError_BAD_MESSAGE ChannelServiceError_ErrorCode = 3
|
||||
ChannelServiceError_INVALID_CHANNEL_TOKEN_DURATION ChannelServiceError_ErrorCode = 4
|
||||
ChannelServiceError_APPID_ALIAS_REQUIRED ChannelServiceError_ErrorCode = 5
|
||||
)
|
||||
|
||||
var ChannelServiceError_ErrorCode_name = map[int32]string{
|
||||
0: "OK",
|
||||
1: "INTERNAL_ERROR",
|
||||
2: "INVALID_CHANNEL_KEY",
|
||||
3: "BAD_MESSAGE",
|
||||
4: "INVALID_CHANNEL_TOKEN_DURATION",
|
||||
5: "APPID_ALIAS_REQUIRED",
|
||||
}
|
||||
var ChannelServiceError_ErrorCode_value = map[string]int32{
|
||||
"OK": 0,
|
||||
"INTERNAL_ERROR": 1,
|
||||
"INVALID_CHANNEL_KEY": 2,
|
||||
"BAD_MESSAGE": 3,
|
||||
"INVALID_CHANNEL_TOKEN_DURATION": 4,
|
||||
"APPID_ALIAS_REQUIRED": 5,
|
||||
}
|
||||
|
||||
func (x ChannelServiceError_ErrorCode) Enum() *ChannelServiceError_ErrorCode {
|
||||
p := new(ChannelServiceError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x ChannelServiceError_ErrorCode) String() string {
|
||||
return proto.EnumName(ChannelServiceError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *ChannelServiceError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(ChannelServiceError_ErrorCode_value, data, "ChannelServiceError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = ChannelServiceError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type ChannelServiceError struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ChannelServiceError) Reset() { *m = ChannelServiceError{} }
|
||||
func (m *ChannelServiceError) String() string { return proto.CompactTextString(m) }
|
||||
func (*ChannelServiceError) ProtoMessage() {}
|
||||
|
||||
type CreateChannelRequest struct {
|
||||
ApplicationKey *string `protobuf:"bytes,1,req,name=application_key" json:"application_key,omitempty"`
|
||||
DurationMinutes *int32 `protobuf:"varint,2,opt,name=duration_minutes" json:"duration_minutes,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CreateChannelRequest) Reset() { *m = CreateChannelRequest{} }
|
||||
func (m *CreateChannelRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*CreateChannelRequest) ProtoMessage() {}
|
||||
|
||||
func (m *CreateChannelRequest) GetApplicationKey() string {
|
||||
if m != nil && m.ApplicationKey != nil {
|
||||
return *m.ApplicationKey
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *CreateChannelRequest) GetDurationMinutes() int32 {
|
||||
if m != nil && m.DurationMinutes != nil {
|
||||
return *m.DurationMinutes
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type CreateChannelResponse struct {
|
||||
Token *string `protobuf:"bytes,2,opt,name=token" json:"token,omitempty"`
|
||||
DurationMinutes *int32 `protobuf:"varint,3,opt,name=duration_minutes" json:"duration_minutes,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CreateChannelResponse) Reset() { *m = CreateChannelResponse{} }
|
||||
func (m *CreateChannelResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*CreateChannelResponse) ProtoMessage() {}
|
||||
|
||||
func (m *CreateChannelResponse) GetToken() string {
|
||||
if m != nil && m.Token != nil {
|
||||
return *m.Token
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *CreateChannelResponse) GetDurationMinutes() int32 {
|
||||
if m != nil && m.DurationMinutes != nil {
|
||||
return *m.DurationMinutes
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type SendMessageRequest struct {
|
||||
ApplicationKey *string `protobuf:"bytes,1,req,name=application_key" json:"application_key,omitempty"`
|
||||
Message *string `protobuf:"bytes,2,req,name=message" json:"message,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *SendMessageRequest) Reset() { *m = SendMessageRequest{} }
|
||||
func (m *SendMessageRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*SendMessageRequest) ProtoMessage() {}
|
||||
|
||||
func (m *SendMessageRequest) GetApplicationKey() string {
|
||||
if m != nil && m.ApplicationKey != nil {
|
||||
return *m.ApplicationKey
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *SendMessageRequest) GetMessage() string {
|
||||
if m != nil && m.Message != nil {
|
||||
return *m.Message
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func init() {
|
||||
}
|
30
vendor/google.golang.org/appengine/internal/channel/channel_service.proto
generated
vendored
Normal file
30
vendor/google.golang.org/appengine/internal/channel/channel_service.proto
generated
vendored
Normal file
@@ -0,0 +1,30 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "channel";
|
||||
|
||||
package appengine;
|
||||
|
||||
message ChannelServiceError {
|
||||
enum ErrorCode {
|
||||
OK = 0;
|
||||
INTERNAL_ERROR = 1;
|
||||
INVALID_CHANNEL_KEY = 2;
|
||||
BAD_MESSAGE = 3;
|
||||
INVALID_CHANNEL_TOKEN_DURATION = 4;
|
||||
APPID_ALIAS_REQUIRED = 5;
|
||||
}
|
||||
}
|
||||
|
||||
message CreateChannelRequest {
|
||||
required string application_key = 1;
|
||||
optional int32 duration_minutes = 2;
|
||||
}
|
||||
|
||||
message CreateChannelResponse {
|
||||
optional string token = 2;
|
||||
optional int32 duration_minutes = 3;
|
||||
}
|
||||
|
||||
message SendMessageRequest {
|
||||
required string application_key = 1;
|
||||
required string message = 2;
|
||||
}
|
2778
vendor/google.golang.org/appengine/internal/datastore/datastore_v3.pb.go
generated
vendored
Normal file
2778
vendor/google.golang.org/appengine/internal/datastore/datastore_v3.pb.go
generated
vendored
Normal file
File diff suppressed because it is too large
Load Diff
541
vendor/google.golang.org/appengine/internal/datastore/datastore_v3.proto
generated
vendored
Normal file
541
vendor/google.golang.org/appengine/internal/datastore/datastore_v3.proto
generated
vendored
Normal file
@@ -0,0 +1,541 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "datastore";
|
||||
|
||||
package appengine;
|
||||
|
||||
message Action{}
|
||||
|
||||
message PropertyValue {
|
||||
optional int64 int64Value = 1;
|
||||
optional bool booleanValue = 2;
|
||||
optional string stringValue = 3;
|
||||
optional double doubleValue = 4;
|
||||
|
||||
optional group PointValue = 5 {
|
||||
required double x = 6;
|
||||
required double y = 7;
|
||||
}
|
||||
|
||||
optional group UserValue = 8 {
|
||||
required string email = 9;
|
||||
required string auth_domain = 10;
|
||||
optional string nickname = 11;
|
||||
optional string federated_identity = 21;
|
||||
optional string federated_provider = 22;
|
||||
}
|
||||
|
||||
optional group ReferenceValue = 12 {
|
||||
required string app = 13;
|
||||
optional string name_space = 20;
|
||||
repeated group PathElement = 14 {
|
||||
required string type = 15;
|
||||
optional int64 id = 16;
|
||||
optional string name = 17;
|
||||
}
|
||||
}
|
||||
}
|
||||
|
||||
message Property {
|
||||
enum Meaning {
|
||||
NO_MEANING = 0;
|
||||
BLOB = 14;
|
||||
TEXT = 15;
|
||||
BYTESTRING = 16;
|
||||
|
||||
ATOM_CATEGORY = 1;
|
||||
ATOM_LINK = 2;
|
||||
ATOM_TITLE = 3;
|
||||
ATOM_CONTENT = 4;
|
||||
ATOM_SUMMARY = 5;
|
||||
ATOM_AUTHOR = 6;
|
||||
|
||||
GD_WHEN = 7;
|
||||
GD_EMAIL = 8;
|
||||
GEORSS_POINT = 9;
|
||||
GD_IM = 10;
|
||||
|
||||
GD_PHONENUMBER = 11;
|
||||
GD_POSTALADDRESS = 12;
|
||||
|
||||
GD_RATING = 13;
|
||||
|
||||
BLOBKEY = 17;
|
||||
ENTITY_PROTO = 19;
|
||||
|
||||
INDEX_VALUE = 18;
|
||||
};
|
||||
|
||||
optional Meaning meaning = 1 [default = NO_MEANING];
|
||||
optional string meaning_uri = 2;
|
||||
|
||||
required string name = 3;
|
||||
|
||||
required PropertyValue value = 5;
|
||||
|
||||
required bool multiple = 4;
|
||||
|
||||
optional bool searchable = 6 [default=false];
|
||||
|
||||
enum FtsTokenizationOption {
|
||||
HTML = 1;
|
||||
ATOM = 2;
|
||||
}
|
||||
|
||||
optional FtsTokenizationOption fts_tokenization_option = 8;
|
||||
|
||||
optional string locale = 9 [default = "en"];
|
||||
}
|
||||
|
||||
message Path {
|
||||
repeated group Element = 1 {
|
||||
required string type = 2;
|
||||
optional int64 id = 3;
|
||||
optional string name = 4;
|
||||
}
|
||||
}
|
||||
|
||||
message Reference {
|
||||
required string app = 13;
|
||||
optional string name_space = 20;
|
||||
required Path path = 14;
|
||||
}
|
||||
|
||||
message User {
|
||||
required string email = 1;
|
||||
required string auth_domain = 2;
|
||||
optional string nickname = 3;
|
||||
optional string federated_identity = 6;
|
||||
optional string federated_provider = 7;
|
||||
}
|
||||
|
||||
message EntityProto {
|
||||
required Reference key = 13;
|
||||
required Path entity_group = 16;
|
||||
optional User owner = 17;
|
||||
|
||||
enum Kind {
|
||||
GD_CONTACT = 1;
|
||||
GD_EVENT = 2;
|
||||
GD_MESSAGE = 3;
|
||||
}
|
||||
optional Kind kind = 4;
|
||||
optional string kind_uri = 5;
|
||||
|
||||
repeated Property property = 14;
|
||||
repeated Property raw_property = 15;
|
||||
|
||||
optional int32 rank = 18;
|
||||
}
|
||||
|
||||
message CompositeProperty {
|
||||
required int64 index_id = 1;
|
||||
repeated string value = 2;
|
||||
}
|
||||
|
||||
message Index {
|
||||
required string entity_type = 1;
|
||||
required bool ancestor = 5;
|
||||
repeated group Property = 2 {
|
||||
required string name = 3;
|
||||
enum Direction {
|
||||
ASCENDING = 1;
|
||||
DESCENDING = 2;
|
||||
}
|
||||
optional Direction direction = 4 [default = ASCENDING];
|
||||
}
|
||||
}
|
||||
|
||||
message CompositeIndex {
|
||||
required string app_id = 1;
|
||||
required int64 id = 2;
|
||||
required Index definition = 3;
|
||||
|
||||
enum State {
|
||||
WRITE_ONLY = 1;
|
||||
READ_WRITE = 2;
|
||||
DELETED = 3;
|
||||
ERROR = 4;
|
||||
}
|
||||
required State state = 4;
|
||||
|
||||
optional bool only_use_if_required = 6 [default = false];
|
||||
}
|
||||
|
||||
message IndexPostfix {
|
||||
message IndexValue {
|
||||
required string property_name = 1;
|
||||
required PropertyValue value = 2;
|
||||
}
|
||||
|
||||
repeated IndexValue index_value = 1;
|
||||
|
||||
optional Reference key = 2;
|
||||
|
||||
optional bool before = 3 [default=true];
|
||||
}
|
||||
|
||||
message IndexPosition {
|
||||
optional string key = 1;
|
||||
|
||||
optional bool before = 2 [default=true];
|
||||
}
|
||||
|
||||
message Snapshot {
|
||||
enum Status {
|
||||
INACTIVE = 0;
|
||||
ACTIVE = 1;
|
||||
}
|
||||
|
||||
required int64 ts = 1;
|
||||
}
|
||||
|
||||
message InternalHeader {
|
||||
optional string qos = 1;
|
||||
}
|
||||
|
||||
message Transaction {
|
||||
optional InternalHeader header = 4;
|
||||
required fixed64 handle = 1;
|
||||
required string app = 2;
|
||||
optional bool mark_changes = 3 [default = false];
|
||||
}
|
||||
|
||||
message Query {
|
||||
optional InternalHeader header = 39;
|
||||
|
||||
required string app = 1;
|
||||
optional string name_space = 29;
|
||||
|
||||
optional string kind = 3;
|
||||
optional Reference ancestor = 17;
|
||||
|
||||
repeated group Filter = 4 {
|
||||
enum Operator {
|
||||
LESS_THAN = 1;
|
||||
LESS_THAN_OR_EQUAL = 2;
|
||||
GREATER_THAN = 3;
|
||||
GREATER_THAN_OR_EQUAL = 4;
|
||||
EQUAL = 5;
|
||||
IN = 6;
|
||||
EXISTS = 7;
|
||||
}
|
||||
|
||||
required Operator op = 6;
|
||||
repeated Property property = 14;
|
||||
}
|
||||
|
||||
optional string search_query = 8;
|
||||
|
||||
repeated group Order = 9 {
|
||||
enum Direction {
|
||||
ASCENDING = 1;
|
||||
DESCENDING = 2;
|
||||
}
|
||||
|
||||
required string property = 10;
|
||||
optional Direction direction = 11 [default = ASCENDING];
|
||||
}
|
||||
|
||||
enum Hint {
|
||||
ORDER_FIRST = 1;
|
||||
ANCESTOR_FIRST = 2;
|
||||
FILTER_FIRST = 3;
|
||||
}
|
||||
optional Hint hint = 18;
|
||||
|
||||
optional int32 count = 23;
|
||||
|
||||
optional int32 offset = 12 [default = 0];
|
||||
|
||||
optional int32 limit = 16;
|
||||
|
||||
optional CompiledCursor compiled_cursor = 30;
|
||||
optional CompiledCursor end_compiled_cursor = 31;
|
||||
|
||||
repeated CompositeIndex composite_index = 19;
|
||||
|
||||
optional bool require_perfect_plan = 20 [default = false];
|
||||
|
||||
optional bool keys_only = 21 [default = false];
|
||||
|
||||
optional Transaction transaction = 22;
|
||||
|
||||
optional bool compile = 25 [default = false];
|
||||
|
||||
optional int64 failover_ms = 26;
|
||||
|
||||
optional bool strong = 32;
|
||||
|
||||
repeated string property_name = 33;
|
||||
|
||||
repeated string group_by_property_name = 34;
|
||||
|
||||
optional bool distinct = 24;
|
||||
|
||||
optional int64 min_safe_time_seconds = 35;
|
||||
|
||||
repeated string safe_replica_name = 36;
|
||||
|
||||
optional bool persist_offset = 37 [default=false];
|
||||
}
|
||||
|
||||
message CompiledQuery {
|
||||
required group PrimaryScan = 1 {
|
||||
optional string index_name = 2;
|
||||
|
||||
optional string start_key = 3;
|
||||
optional bool start_inclusive = 4;
|
||||
optional string end_key = 5;
|
||||
optional bool end_inclusive = 6;
|
||||
|
||||
repeated string start_postfix_value = 22;
|
||||
repeated string end_postfix_value = 23;
|
||||
|
||||
optional int64 end_unapplied_log_timestamp_us = 19;
|
||||
}
|
||||
|
||||
repeated group MergeJoinScan = 7 {
|
||||
required string index_name = 8;
|
||||
|
||||
repeated string prefix_value = 9;
|
||||
|
||||
optional bool value_prefix = 20 [default=false];
|
||||
}
|
||||
|
||||
optional Index index_def = 21;
|
||||
|
||||
optional int32 offset = 10 [default = 0];
|
||||
|
||||
optional int32 limit = 11;
|
||||
|
||||
required bool keys_only = 12;
|
||||
|
||||
repeated string property_name = 24;
|
||||
|
||||
optional int32 distinct_infix_size = 25;
|
||||
|
||||
optional group EntityFilter = 13 {
|
||||
optional bool distinct = 14 [default=false];
|
||||
|
||||
optional string kind = 17;
|
||||
optional Reference ancestor = 18;
|
||||
}
|
||||
}
|
||||
|
||||
message CompiledCursor {
|
||||
optional group Position = 2 {
|
||||
optional string start_key = 27;
|
||||
|
||||
repeated group IndexValue = 29 {
|
||||
optional string property = 30;
|
||||
required PropertyValue value = 31;
|
||||
}
|
||||
|
||||
optional Reference key = 32;
|
||||
|
||||
optional bool start_inclusive = 28 [default=true];
|
||||
}
|
||||
}
|
||||
|
||||
message Cursor {
|
||||
required fixed64 cursor = 1;
|
||||
|
||||
optional string app = 2;
|
||||
}
|
||||
|
||||
message Error {
|
||||
enum ErrorCode {
|
||||
BAD_REQUEST = 1;
|
||||
CONCURRENT_TRANSACTION = 2;
|
||||
INTERNAL_ERROR = 3;
|
||||
NEED_INDEX = 4;
|
||||
TIMEOUT = 5;
|
||||
PERMISSION_DENIED = 6;
|
||||
BIGTABLE_ERROR = 7;
|
||||
COMMITTED_BUT_STILL_APPLYING = 8;
|
||||
CAPABILITY_DISABLED = 9;
|
||||
TRY_ALTERNATE_BACKEND = 10;
|
||||
SAFE_TIME_TOO_OLD = 11;
|
||||
}
|
||||
}
|
||||
|
||||
message Cost {
|
||||
optional int32 index_writes = 1;
|
||||
optional int32 index_write_bytes = 2;
|
||||
optional int32 entity_writes = 3;
|
||||
optional int32 entity_write_bytes = 4;
|
||||
optional group CommitCost = 5 {
|
||||
optional int32 requested_entity_puts = 6;
|
||||
optional int32 requested_entity_deletes = 7;
|
||||
};
|
||||
optional int32 approximate_storage_delta = 8;
|
||||
optional int32 id_sequence_updates = 9;
|
||||
}
|
||||
|
||||
message GetRequest {
|
||||
optional InternalHeader header = 6;
|
||||
|
||||
repeated Reference key = 1;
|
||||
optional Transaction transaction = 2;
|
||||
|
||||
optional int64 failover_ms = 3;
|
||||
|
||||
optional bool strong = 4;
|
||||
|
||||
optional bool allow_deferred = 5 [default=false];
|
||||
}
|
||||
|
||||
message GetResponse {
|
||||
repeated group Entity = 1 {
|
||||
optional EntityProto entity = 2;
|
||||
optional Reference key = 4;
|
||||
|
||||
optional int64 version = 3;
|
||||
}
|
||||
|
||||
repeated Reference deferred = 5;
|
||||
|
||||
optional bool in_order = 6 [default=true];
|
||||
}
|
||||
|
||||
message PutRequest {
|
||||
optional InternalHeader header = 11;
|
||||
|
||||
repeated EntityProto entity = 1;
|
||||
optional Transaction transaction = 2;
|
||||
repeated CompositeIndex composite_index = 3;
|
||||
|
||||
optional bool trusted = 4 [default = false];
|
||||
|
||||
optional bool force = 7 [default = false];
|
||||
|
||||
optional bool mark_changes = 8 [default = false];
|
||||
repeated Snapshot snapshot = 9;
|
||||
|
||||
enum AutoIdPolicy {
|
||||
CURRENT = 0;
|
||||
SEQUENTIAL = 1;
|
||||
}
|
||||
optional AutoIdPolicy auto_id_policy = 10 [default = CURRENT];
|
||||
}
|
||||
|
||||
message PutResponse {
|
||||
repeated Reference key = 1;
|
||||
optional Cost cost = 2;
|
||||
repeated int64 version = 3;
|
||||
}
|
||||
|
||||
message TouchRequest {
|
||||
optional InternalHeader header = 10;
|
||||
|
||||
repeated Reference key = 1;
|
||||
repeated CompositeIndex composite_index = 2;
|
||||
optional bool force = 3 [default = false];
|
||||
repeated Snapshot snapshot = 9;
|
||||
}
|
||||
|
||||
message TouchResponse {
|
||||
optional Cost cost = 1;
|
||||
}
|
||||
|
||||
message DeleteRequest {
|
||||
optional InternalHeader header = 10;
|
||||
|
||||
repeated Reference key = 6;
|
||||
optional Transaction transaction = 5;
|
||||
|
||||
optional bool trusted = 4 [default = false];
|
||||
|
||||
optional bool force = 7 [default = false];
|
||||
|
||||
optional bool mark_changes = 8 [default = false];
|
||||
repeated Snapshot snapshot = 9;
|
||||
}
|
||||
|
||||
message DeleteResponse {
|
||||
optional Cost cost = 1;
|
||||
repeated int64 version = 3;
|
||||
}
|
||||
|
||||
message NextRequest {
|
||||
optional InternalHeader header = 5;
|
||||
|
||||
required Cursor cursor = 1;
|
||||
optional int32 count = 2;
|
||||
|
||||
optional int32 offset = 4 [default = 0];
|
||||
|
||||
optional bool compile = 3 [default = false];
|
||||
}
|
||||
|
||||
message QueryResult {
|
||||
optional Cursor cursor = 1;
|
||||
|
||||
repeated EntityProto result = 2;
|
||||
|
||||
optional int32 skipped_results = 7;
|
||||
|
||||
required bool more_results = 3;
|
||||
|
||||
optional bool keys_only = 4;
|
||||
|
||||
optional bool index_only = 9;
|
||||
|
||||
optional bool small_ops = 10;
|
||||
|
||||
optional CompiledQuery compiled_query = 5;
|
||||
|
||||
optional CompiledCursor compiled_cursor = 6;
|
||||
|
||||
repeated CompositeIndex index = 8;
|
||||
|
||||
repeated int64 version = 11;
|
||||
}
|
||||
|
||||
message AllocateIdsRequest {
|
||||
optional InternalHeader header = 4;
|
||||
|
||||
optional Reference model_key = 1;
|
||||
|
||||
optional int64 size = 2;
|
||||
|
||||
optional int64 max = 3;
|
||||
|
||||
repeated Reference reserve = 5;
|
||||
}
|
||||
|
||||
message AllocateIdsResponse {
|
||||
required int64 start = 1;
|
||||
required int64 end = 2;
|
||||
optional Cost cost = 3;
|
||||
}
|
||||
|
||||
message CompositeIndices {
|
||||
repeated CompositeIndex index = 1;
|
||||
}
|
||||
|
||||
message AddActionsRequest {
|
||||
optional InternalHeader header = 3;
|
||||
|
||||
required Transaction transaction = 1;
|
||||
repeated Action action = 2;
|
||||
}
|
||||
|
||||
message AddActionsResponse {
|
||||
}
|
||||
|
||||
message BeginTransactionRequest {
|
||||
optional InternalHeader header = 3;
|
||||
|
||||
required string app = 1;
|
||||
optional bool allow_multiple_eg = 2 [default = false];
|
||||
}
|
||||
|
||||
message CommitResponse {
|
||||
optional Cost cost = 1;
|
||||
|
||||
repeated group Version = 3 {
|
||||
required Reference root_entity_key = 4;
|
||||
required int64 version = 5;
|
||||
}
|
||||
}
|
14
vendor/google.golang.org/appengine/internal/identity.go
generated
vendored
Normal file
14
vendor/google.golang.org/appengine/internal/identity.go
generated
vendored
Normal file
@@ -0,0 +1,14 @@
|
||||
// Copyright 2011 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
package internal
|
||||
|
||||
import netcontext "golang.org/x/net/context"
|
||||
|
||||
// These functions are implementations of the wrapper functions
|
||||
// in ../appengine/identity.go. See that file for commentary.
|
||||
|
||||
func AppID(c netcontext.Context) string {
|
||||
return appID(FullyQualifiedAppID(c))
|
||||
}
|
27
vendor/google.golang.org/appengine/internal/identity_classic.go
generated
vendored
Normal file
27
vendor/google.golang.org/appengine/internal/identity_classic.go
generated
vendored
Normal file
@@ -0,0 +1,27 @@
|
||||
// Copyright 2015 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
// +build appengine
|
||||
|
||||
package internal
|
||||
|
||||
import (
|
||||
"appengine"
|
||||
|
||||
netcontext "golang.org/x/net/context"
|
||||
)
|
||||
|
||||
func DefaultVersionHostname(ctx netcontext.Context) string {
|
||||
return appengine.DefaultVersionHostname(fromContext(ctx))
|
||||
}
|
||||
|
||||
func RequestID(ctx netcontext.Context) string { return appengine.RequestID(fromContext(ctx)) }
|
||||
func Datacenter(_ netcontext.Context) string { return appengine.Datacenter() }
|
||||
func ServerSoftware() string { return appengine.ServerSoftware() }
|
||||
func ModuleName(ctx netcontext.Context) string { return appengine.ModuleName(fromContext(ctx)) }
|
||||
func VersionID(ctx netcontext.Context) string { return appengine.VersionID(fromContext(ctx)) }
|
||||
func InstanceID() string { return appengine.InstanceID() }
|
||||
func IsDevAppServer() bool { return appengine.IsDevAppServer() }
|
||||
|
||||
func fullyQualifiedAppID(ctx netcontext.Context) string { return fromContext(ctx).FullyQualifiedAppID() }
|
97
vendor/google.golang.org/appengine/internal/identity_vm.go
generated
vendored
Normal file
97
vendor/google.golang.org/appengine/internal/identity_vm.go
generated
vendored
Normal file
@@ -0,0 +1,97 @@
|
||||
// Copyright 2011 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
// +build !appengine
|
||||
|
||||
package internal
|
||||
|
||||
import (
|
||||
"net/http"
|
||||
"os"
|
||||
|
||||
netcontext "golang.org/x/net/context"
|
||||
)
|
||||
|
||||
// These functions are implementations of the wrapper functions
|
||||
// in ../appengine/identity.go. See that file for commentary.
|
||||
|
||||
const (
|
||||
hDefaultVersionHostname = "X-AppEngine-Default-Version-Hostname"
|
||||
hRequestLogId = "X-AppEngine-Request-Log-Id"
|
||||
hDatacenter = "X-AppEngine-Datacenter"
|
||||
)
|
||||
|
||||
func ctxHeaders(ctx netcontext.Context) http.Header {
|
||||
return fromContext(ctx).Request().Header
|
||||
}
|
||||
|
||||
func DefaultVersionHostname(ctx netcontext.Context) string {
|
||||
return ctxHeaders(ctx).Get(hDefaultVersionHostname)
|
||||
}
|
||||
|
||||
func RequestID(ctx netcontext.Context) string {
|
||||
return ctxHeaders(ctx).Get(hRequestLogId)
|
||||
}
|
||||
|
||||
func Datacenter(ctx netcontext.Context) string {
|
||||
return ctxHeaders(ctx).Get(hDatacenter)
|
||||
}
|
||||
|
||||
func ServerSoftware() string {
|
||||
// TODO(dsymonds): Remove fallback when we've verified this.
|
||||
if s := os.Getenv("SERVER_SOFTWARE"); s != "" {
|
||||
return s
|
||||
}
|
||||
return "Google App Engine/1.x.x"
|
||||
}
|
||||
|
||||
// TODO(dsymonds): Remove the metadata fetches.
|
||||
|
||||
func ModuleName(_ netcontext.Context) string {
|
||||
if s := os.Getenv("GAE_MODULE_NAME"); s != "" {
|
||||
return s
|
||||
}
|
||||
return string(mustGetMetadata("instance/attributes/gae_backend_name"))
|
||||
}
|
||||
|
||||
func VersionID(_ netcontext.Context) string {
|
||||
if s1, s2 := os.Getenv("GAE_MODULE_VERSION"), os.Getenv("GAE_MINOR_VERSION"); s1 != "" && s2 != "" {
|
||||
return s1 + "." + s2
|
||||
}
|
||||
return string(mustGetMetadata("instance/attributes/gae_backend_version")) + "." + string(mustGetMetadata("instance/attributes/gae_backend_minor_version"))
|
||||
}
|
||||
|
||||
func InstanceID() string {
|
||||
if s := os.Getenv("GAE_MODULE_INSTANCE"); s != "" {
|
||||
return s
|
||||
}
|
||||
return string(mustGetMetadata("instance/attributes/gae_backend_instance"))
|
||||
}
|
||||
|
||||
func partitionlessAppID() string {
|
||||
// gae_project has everything except the partition prefix.
|
||||
appID := os.Getenv("GAE_LONG_APP_ID")
|
||||
if appID == "" {
|
||||
appID = string(mustGetMetadata("instance/attributes/gae_project"))
|
||||
}
|
||||
return appID
|
||||
}
|
||||
|
||||
func fullyQualifiedAppID(_ netcontext.Context) string {
|
||||
appID := partitionlessAppID()
|
||||
|
||||
part := os.Getenv("GAE_PARTITION")
|
||||
if part == "" {
|
||||
part = string(mustGetMetadata("instance/attributes/gae_partition"))
|
||||
}
|
||||
|
||||
if part != "" {
|
||||
appID = part + "~" + appID
|
||||
}
|
||||
return appID
|
||||
}
|
||||
|
||||
func IsDevAppServer() bool {
|
||||
return os.Getenv("RUN_WITH_DEVAPPSERVER") != ""
|
||||
}
|
845
vendor/google.golang.org/appengine/internal/image/images_service.pb.go
generated
vendored
Normal file
845
vendor/google.golang.org/appengine/internal/image/images_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,845 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/image/images_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package image is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/image/images_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
ImagesServiceError
|
||||
ImagesServiceTransform
|
||||
Transform
|
||||
ImageData
|
||||
InputSettings
|
||||
OutputSettings
|
||||
ImagesTransformRequest
|
||||
ImagesTransformResponse
|
||||
CompositeImageOptions
|
||||
ImagesCanvas
|
||||
ImagesCompositeRequest
|
||||
ImagesCompositeResponse
|
||||
ImagesHistogramRequest
|
||||
ImagesHistogram
|
||||
ImagesHistogramResponse
|
||||
ImagesGetUrlBaseRequest
|
||||
ImagesGetUrlBaseResponse
|
||||
ImagesDeleteUrlBaseRequest
|
||||
ImagesDeleteUrlBaseResponse
|
||||
*/
|
||||
package image
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type ImagesServiceError_ErrorCode int32
|
||||
|
||||
const (
|
||||
ImagesServiceError_UNSPECIFIED_ERROR ImagesServiceError_ErrorCode = 1
|
||||
ImagesServiceError_BAD_TRANSFORM_DATA ImagesServiceError_ErrorCode = 2
|
||||
ImagesServiceError_NOT_IMAGE ImagesServiceError_ErrorCode = 3
|
||||
ImagesServiceError_BAD_IMAGE_DATA ImagesServiceError_ErrorCode = 4
|
||||
ImagesServiceError_IMAGE_TOO_LARGE ImagesServiceError_ErrorCode = 5
|
||||
ImagesServiceError_INVALID_BLOB_KEY ImagesServiceError_ErrorCode = 6
|
||||
ImagesServiceError_ACCESS_DENIED ImagesServiceError_ErrorCode = 7
|
||||
ImagesServiceError_OBJECT_NOT_FOUND ImagesServiceError_ErrorCode = 8
|
||||
)
|
||||
|
||||
var ImagesServiceError_ErrorCode_name = map[int32]string{
|
||||
1: "UNSPECIFIED_ERROR",
|
||||
2: "BAD_TRANSFORM_DATA",
|
||||
3: "NOT_IMAGE",
|
||||
4: "BAD_IMAGE_DATA",
|
||||
5: "IMAGE_TOO_LARGE",
|
||||
6: "INVALID_BLOB_KEY",
|
||||
7: "ACCESS_DENIED",
|
||||
8: "OBJECT_NOT_FOUND",
|
||||
}
|
||||
var ImagesServiceError_ErrorCode_value = map[string]int32{
|
||||
"UNSPECIFIED_ERROR": 1,
|
||||
"BAD_TRANSFORM_DATA": 2,
|
||||
"NOT_IMAGE": 3,
|
||||
"BAD_IMAGE_DATA": 4,
|
||||
"IMAGE_TOO_LARGE": 5,
|
||||
"INVALID_BLOB_KEY": 6,
|
||||
"ACCESS_DENIED": 7,
|
||||
"OBJECT_NOT_FOUND": 8,
|
||||
}
|
||||
|
||||
func (x ImagesServiceError_ErrorCode) Enum() *ImagesServiceError_ErrorCode {
|
||||
p := new(ImagesServiceError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x ImagesServiceError_ErrorCode) String() string {
|
||||
return proto.EnumName(ImagesServiceError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *ImagesServiceError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(ImagesServiceError_ErrorCode_value, data, "ImagesServiceError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = ImagesServiceError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type ImagesServiceTransform_Type int32
|
||||
|
||||
const (
|
||||
ImagesServiceTransform_RESIZE ImagesServiceTransform_Type = 1
|
||||
ImagesServiceTransform_ROTATE ImagesServiceTransform_Type = 2
|
||||
ImagesServiceTransform_HORIZONTAL_FLIP ImagesServiceTransform_Type = 3
|
||||
ImagesServiceTransform_VERTICAL_FLIP ImagesServiceTransform_Type = 4
|
||||
ImagesServiceTransform_CROP ImagesServiceTransform_Type = 5
|
||||
ImagesServiceTransform_IM_FEELING_LUCKY ImagesServiceTransform_Type = 6
|
||||
)
|
||||
|
||||
var ImagesServiceTransform_Type_name = map[int32]string{
|
||||
1: "RESIZE",
|
||||
2: "ROTATE",
|
||||
3: "HORIZONTAL_FLIP",
|
||||
4: "VERTICAL_FLIP",
|
||||
5: "CROP",
|
||||
6: "IM_FEELING_LUCKY",
|
||||
}
|
||||
var ImagesServiceTransform_Type_value = map[string]int32{
|
||||
"RESIZE": 1,
|
||||
"ROTATE": 2,
|
||||
"HORIZONTAL_FLIP": 3,
|
||||
"VERTICAL_FLIP": 4,
|
||||
"CROP": 5,
|
||||
"IM_FEELING_LUCKY": 6,
|
||||
}
|
||||
|
||||
func (x ImagesServiceTransform_Type) Enum() *ImagesServiceTransform_Type {
|
||||
p := new(ImagesServiceTransform_Type)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x ImagesServiceTransform_Type) String() string {
|
||||
return proto.EnumName(ImagesServiceTransform_Type_name, int32(x))
|
||||
}
|
||||
func (x *ImagesServiceTransform_Type) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(ImagesServiceTransform_Type_value, data, "ImagesServiceTransform_Type")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = ImagesServiceTransform_Type(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type InputSettings_ORIENTATION_CORRECTION_TYPE int32
|
||||
|
||||
const (
|
||||
InputSettings_UNCHANGED_ORIENTATION InputSettings_ORIENTATION_CORRECTION_TYPE = 0
|
||||
InputSettings_CORRECT_ORIENTATION InputSettings_ORIENTATION_CORRECTION_TYPE = 1
|
||||
)
|
||||
|
||||
var InputSettings_ORIENTATION_CORRECTION_TYPE_name = map[int32]string{
|
||||
0: "UNCHANGED_ORIENTATION",
|
||||
1: "CORRECT_ORIENTATION",
|
||||
}
|
||||
var InputSettings_ORIENTATION_CORRECTION_TYPE_value = map[string]int32{
|
||||
"UNCHANGED_ORIENTATION": 0,
|
||||
"CORRECT_ORIENTATION": 1,
|
||||
}
|
||||
|
||||
func (x InputSettings_ORIENTATION_CORRECTION_TYPE) Enum() *InputSettings_ORIENTATION_CORRECTION_TYPE {
|
||||
p := new(InputSettings_ORIENTATION_CORRECTION_TYPE)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x InputSettings_ORIENTATION_CORRECTION_TYPE) String() string {
|
||||
return proto.EnumName(InputSettings_ORIENTATION_CORRECTION_TYPE_name, int32(x))
|
||||
}
|
||||
func (x *InputSettings_ORIENTATION_CORRECTION_TYPE) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(InputSettings_ORIENTATION_CORRECTION_TYPE_value, data, "InputSettings_ORIENTATION_CORRECTION_TYPE")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = InputSettings_ORIENTATION_CORRECTION_TYPE(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type OutputSettings_MIME_TYPE int32
|
||||
|
||||
const (
|
||||
OutputSettings_PNG OutputSettings_MIME_TYPE = 0
|
||||
OutputSettings_JPEG OutputSettings_MIME_TYPE = 1
|
||||
OutputSettings_WEBP OutputSettings_MIME_TYPE = 2
|
||||
)
|
||||
|
||||
var OutputSettings_MIME_TYPE_name = map[int32]string{
|
||||
0: "PNG",
|
||||
1: "JPEG",
|
||||
2: "WEBP",
|
||||
}
|
||||
var OutputSettings_MIME_TYPE_value = map[string]int32{
|
||||
"PNG": 0,
|
||||
"JPEG": 1,
|
||||
"WEBP": 2,
|
||||
}
|
||||
|
||||
func (x OutputSettings_MIME_TYPE) Enum() *OutputSettings_MIME_TYPE {
|
||||
p := new(OutputSettings_MIME_TYPE)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x OutputSettings_MIME_TYPE) String() string {
|
||||
return proto.EnumName(OutputSettings_MIME_TYPE_name, int32(x))
|
||||
}
|
||||
func (x *OutputSettings_MIME_TYPE) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(OutputSettings_MIME_TYPE_value, data, "OutputSettings_MIME_TYPE")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = OutputSettings_MIME_TYPE(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type CompositeImageOptions_ANCHOR int32
|
||||
|
||||
const (
|
||||
CompositeImageOptions_TOP_LEFT CompositeImageOptions_ANCHOR = 0
|
||||
CompositeImageOptions_TOP CompositeImageOptions_ANCHOR = 1
|
||||
CompositeImageOptions_TOP_RIGHT CompositeImageOptions_ANCHOR = 2
|
||||
CompositeImageOptions_LEFT CompositeImageOptions_ANCHOR = 3
|
||||
CompositeImageOptions_CENTER CompositeImageOptions_ANCHOR = 4
|
||||
CompositeImageOptions_RIGHT CompositeImageOptions_ANCHOR = 5
|
||||
CompositeImageOptions_BOTTOM_LEFT CompositeImageOptions_ANCHOR = 6
|
||||
CompositeImageOptions_BOTTOM CompositeImageOptions_ANCHOR = 7
|
||||
CompositeImageOptions_BOTTOM_RIGHT CompositeImageOptions_ANCHOR = 8
|
||||
)
|
||||
|
||||
var CompositeImageOptions_ANCHOR_name = map[int32]string{
|
||||
0: "TOP_LEFT",
|
||||
1: "TOP",
|
||||
2: "TOP_RIGHT",
|
||||
3: "LEFT",
|
||||
4: "CENTER",
|
||||
5: "RIGHT",
|
||||
6: "BOTTOM_LEFT",
|
||||
7: "BOTTOM",
|
||||
8: "BOTTOM_RIGHT",
|
||||
}
|
||||
var CompositeImageOptions_ANCHOR_value = map[string]int32{
|
||||
"TOP_LEFT": 0,
|
||||
"TOP": 1,
|
||||
"TOP_RIGHT": 2,
|
||||
"LEFT": 3,
|
||||
"CENTER": 4,
|
||||
"RIGHT": 5,
|
||||
"BOTTOM_LEFT": 6,
|
||||
"BOTTOM": 7,
|
||||
"BOTTOM_RIGHT": 8,
|
||||
}
|
||||
|
||||
func (x CompositeImageOptions_ANCHOR) Enum() *CompositeImageOptions_ANCHOR {
|
||||
p := new(CompositeImageOptions_ANCHOR)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x CompositeImageOptions_ANCHOR) String() string {
|
||||
return proto.EnumName(CompositeImageOptions_ANCHOR_name, int32(x))
|
||||
}
|
||||
func (x *CompositeImageOptions_ANCHOR) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(CompositeImageOptions_ANCHOR_value, data, "CompositeImageOptions_ANCHOR")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = CompositeImageOptions_ANCHOR(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type ImagesServiceError struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesServiceError) Reset() { *m = ImagesServiceError{} }
|
||||
func (m *ImagesServiceError) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesServiceError) ProtoMessage() {}
|
||||
|
||||
type ImagesServiceTransform struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesServiceTransform) Reset() { *m = ImagesServiceTransform{} }
|
||||
func (m *ImagesServiceTransform) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesServiceTransform) ProtoMessage() {}
|
||||
|
||||
type Transform struct {
|
||||
Width *int32 `protobuf:"varint,1,opt,name=width" json:"width,omitempty"`
|
||||
Height *int32 `protobuf:"varint,2,opt,name=height" json:"height,omitempty"`
|
||||
CropToFit *bool `protobuf:"varint,11,opt,name=crop_to_fit,def=0" json:"crop_to_fit,omitempty"`
|
||||
CropOffsetX *float32 `protobuf:"fixed32,12,opt,name=crop_offset_x,def=0.5" json:"crop_offset_x,omitempty"`
|
||||
CropOffsetY *float32 `protobuf:"fixed32,13,opt,name=crop_offset_y,def=0.5" json:"crop_offset_y,omitempty"`
|
||||
Rotate *int32 `protobuf:"varint,3,opt,name=rotate,def=0" json:"rotate,omitempty"`
|
||||
HorizontalFlip *bool `protobuf:"varint,4,opt,name=horizontal_flip,def=0" json:"horizontal_flip,omitempty"`
|
||||
VerticalFlip *bool `protobuf:"varint,5,opt,name=vertical_flip,def=0" json:"vertical_flip,omitempty"`
|
||||
CropLeftX *float32 `protobuf:"fixed32,6,opt,name=crop_left_x,def=0" json:"crop_left_x,omitempty"`
|
||||
CropTopY *float32 `protobuf:"fixed32,7,opt,name=crop_top_y,def=0" json:"crop_top_y,omitempty"`
|
||||
CropRightX *float32 `protobuf:"fixed32,8,opt,name=crop_right_x,def=1" json:"crop_right_x,omitempty"`
|
||||
CropBottomY *float32 `protobuf:"fixed32,9,opt,name=crop_bottom_y,def=1" json:"crop_bottom_y,omitempty"`
|
||||
Autolevels *bool `protobuf:"varint,10,opt,name=autolevels,def=0" json:"autolevels,omitempty"`
|
||||
AllowStretch *bool `protobuf:"varint,14,opt,name=allow_stretch,def=0" json:"allow_stretch,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *Transform) Reset() { *m = Transform{} }
|
||||
func (m *Transform) String() string { return proto.CompactTextString(m) }
|
||||
func (*Transform) ProtoMessage() {}
|
||||
|
||||
const Default_Transform_CropToFit bool = false
|
||||
const Default_Transform_CropOffsetX float32 = 0.5
|
||||
const Default_Transform_CropOffsetY float32 = 0.5
|
||||
const Default_Transform_Rotate int32 = 0
|
||||
const Default_Transform_HorizontalFlip bool = false
|
||||
const Default_Transform_VerticalFlip bool = false
|
||||
const Default_Transform_CropLeftX float32 = 0
|
||||
const Default_Transform_CropTopY float32 = 0
|
||||
const Default_Transform_CropRightX float32 = 1
|
||||
const Default_Transform_CropBottomY float32 = 1
|
||||
const Default_Transform_Autolevels bool = false
|
||||
const Default_Transform_AllowStretch bool = false
|
||||
|
||||
func (m *Transform) GetWidth() int32 {
|
||||
if m != nil && m.Width != nil {
|
||||
return *m.Width
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *Transform) GetHeight() int32 {
|
||||
if m != nil && m.Height != nil {
|
||||
return *m.Height
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *Transform) GetCropToFit() bool {
|
||||
if m != nil && m.CropToFit != nil {
|
||||
return *m.CropToFit
|
||||
}
|
||||
return Default_Transform_CropToFit
|
||||
}
|
||||
|
||||
func (m *Transform) GetCropOffsetX() float32 {
|
||||
if m != nil && m.CropOffsetX != nil {
|
||||
return *m.CropOffsetX
|
||||
}
|
||||
return Default_Transform_CropOffsetX
|
||||
}
|
||||
|
||||
func (m *Transform) GetCropOffsetY() float32 {
|
||||
if m != nil && m.CropOffsetY != nil {
|
||||
return *m.CropOffsetY
|
||||
}
|
||||
return Default_Transform_CropOffsetY
|
||||
}
|
||||
|
||||
func (m *Transform) GetRotate() int32 {
|
||||
if m != nil && m.Rotate != nil {
|
||||
return *m.Rotate
|
||||
}
|
||||
return Default_Transform_Rotate
|
||||
}
|
||||
|
||||
func (m *Transform) GetHorizontalFlip() bool {
|
||||
if m != nil && m.HorizontalFlip != nil {
|
||||
return *m.HorizontalFlip
|
||||
}
|
||||
return Default_Transform_HorizontalFlip
|
||||
}
|
||||
|
||||
func (m *Transform) GetVerticalFlip() bool {
|
||||
if m != nil && m.VerticalFlip != nil {
|
||||
return *m.VerticalFlip
|
||||
}
|
||||
return Default_Transform_VerticalFlip
|
||||
}
|
||||
|
||||
func (m *Transform) GetCropLeftX() float32 {
|
||||
if m != nil && m.CropLeftX != nil {
|
||||
return *m.CropLeftX
|
||||
}
|
||||
return Default_Transform_CropLeftX
|
||||
}
|
||||
|
||||
func (m *Transform) GetCropTopY() float32 {
|
||||
if m != nil && m.CropTopY != nil {
|
||||
return *m.CropTopY
|
||||
}
|
||||
return Default_Transform_CropTopY
|
||||
}
|
||||
|
||||
func (m *Transform) GetCropRightX() float32 {
|
||||
if m != nil && m.CropRightX != nil {
|
||||
return *m.CropRightX
|
||||
}
|
||||
return Default_Transform_CropRightX
|
||||
}
|
||||
|
||||
func (m *Transform) GetCropBottomY() float32 {
|
||||
if m != nil && m.CropBottomY != nil {
|
||||
return *m.CropBottomY
|
||||
}
|
||||
return Default_Transform_CropBottomY
|
||||
}
|
||||
|
||||
func (m *Transform) GetAutolevels() bool {
|
||||
if m != nil && m.Autolevels != nil {
|
||||
return *m.Autolevels
|
||||
}
|
||||
return Default_Transform_Autolevels
|
||||
}
|
||||
|
||||
func (m *Transform) GetAllowStretch() bool {
|
||||
if m != nil && m.AllowStretch != nil {
|
||||
return *m.AllowStretch
|
||||
}
|
||||
return Default_Transform_AllowStretch
|
||||
}
|
||||
|
||||
type ImageData struct {
|
||||
Content []byte `protobuf:"bytes,1,req,name=content" json:"content,omitempty"`
|
||||
BlobKey *string `protobuf:"bytes,2,opt,name=blob_key" json:"blob_key,omitempty"`
|
||||
Width *int32 `protobuf:"varint,3,opt,name=width" json:"width,omitempty"`
|
||||
Height *int32 `protobuf:"varint,4,opt,name=height" json:"height,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImageData) Reset() { *m = ImageData{} }
|
||||
func (m *ImageData) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImageData) ProtoMessage() {}
|
||||
|
||||
func (m *ImageData) GetContent() []byte {
|
||||
if m != nil {
|
||||
return m.Content
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *ImageData) GetBlobKey() string {
|
||||
if m != nil && m.BlobKey != nil {
|
||||
return *m.BlobKey
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *ImageData) GetWidth() int32 {
|
||||
if m != nil && m.Width != nil {
|
||||
return *m.Width
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *ImageData) GetHeight() int32 {
|
||||
if m != nil && m.Height != nil {
|
||||
return *m.Height
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type InputSettings struct {
|
||||
CorrectExifOrientation *InputSettings_ORIENTATION_CORRECTION_TYPE `protobuf:"varint,1,opt,name=correct_exif_orientation,enum=appengine.InputSettings_ORIENTATION_CORRECTION_TYPE,def=0" json:"correct_exif_orientation,omitempty"`
|
||||
ParseMetadata *bool `protobuf:"varint,2,opt,name=parse_metadata,def=0" json:"parse_metadata,omitempty"`
|
||||
TransparentSubstitutionRgb *int32 `protobuf:"varint,3,opt,name=transparent_substitution_rgb" json:"transparent_substitution_rgb,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *InputSettings) Reset() { *m = InputSettings{} }
|
||||
func (m *InputSettings) String() string { return proto.CompactTextString(m) }
|
||||
func (*InputSettings) ProtoMessage() {}
|
||||
|
||||
const Default_InputSettings_CorrectExifOrientation InputSettings_ORIENTATION_CORRECTION_TYPE = InputSettings_UNCHANGED_ORIENTATION
|
||||
const Default_InputSettings_ParseMetadata bool = false
|
||||
|
||||
func (m *InputSettings) GetCorrectExifOrientation() InputSettings_ORIENTATION_CORRECTION_TYPE {
|
||||
if m != nil && m.CorrectExifOrientation != nil {
|
||||
return *m.CorrectExifOrientation
|
||||
}
|
||||
return Default_InputSettings_CorrectExifOrientation
|
||||
}
|
||||
|
||||
func (m *InputSettings) GetParseMetadata() bool {
|
||||
if m != nil && m.ParseMetadata != nil {
|
||||
return *m.ParseMetadata
|
||||
}
|
||||
return Default_InputSettings_ParseMetadata
|
||||
}
|
||||
|
||||
func (m *InputSettings) GetTransparentSubstitutionRgb() int32 {
|
||||
if m != nil && m.TransparentSubstitutionRgb != nil {
|
||||
return *m.TransparentSubstitutionRgb
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type OutputSettings struct {
|
||||
MimeType *OutputSettings_MIME_TYPE `protobuf:"varint,1,opt,name=mime_type,enum=appengine.OutputSettings_MIME_TYPE,def=0" json:"mime_type,omitempty"`
|
||||
Quality *int32 `protobuf:"varint,2,opt,name=quality" json:"quality,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *OutputSettings) Reset() { *m = OutputSettings{} }
|
||||
func (m *OutputSettings) String() string { return proto.CompactTextString(m) }
|
||||
func (*OutputSettings) ProtoMessage() {}
|
||||
|
||||
const Default_OutputSettings_MimeType OutputSettings_MIME_TYPE = OutputSettings_PNG
|
||||
|
||||
func (m *OutputSettings) GetMimeType() OutputSettings_MIME_TYPE {
|
||||
if m != nil && m.MimeType != nil {
|
||||
return *m.MimeType
|
||||
}
|
||||
return Default_OutputSettings_MimeType
|
||||
}
|
||||
|
||||
func (m *OutputSettings) GetQuality() int32 {
|
||||
if m != nil && m.Quality != nil {
|
||||
return *m.Quality
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type ImagesTransformRequest struct {
|
||||
Image *ImageData `protobuf:"bytes,1,req,name=image" json:"image,omitempty"`
|
||||
Transform []*Transform `protobuf:"bytes,2,rep,name=transform" json:"transform,omitempty"`
|
||||
Output *OutputSettings `protobuf:"bytes,3,req,name=output" json:"output,omitempty"`
|
||||
Input *InputSettings `protobuf:"bytes,4,opt,name=input" json:"input,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesTransformRequest) Reset() { *m = ImagesTransformRequest{} }
|
||||
func (m *ImagesTransformRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesTransformRequest) ProtoMessage() {}
|
||||
|
||||
func (m *ImagesTransformRequest) GetImage() *ImageData {
|
||||
if m != nil {
|
||||
return m.Image
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *ImagesTransformRequest) GetTransform() []*Transform {
|
||||
if m != nil {
|
||||
return m.Transform
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *ImagesTransformRequest) GetOutput() *OutputSettings {
|
||||
if m != nil {
|
||||
return m.Output
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *ImagesTransformRequest) GetInput() *InputSettings {
|
||||
if m != nil {
|
||||
return m.Input
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type ImagesTransformResponse struct {
|
||||
Image *ImageData `protobuf:"bytes,1,req,name=image" json:"image,omitempty"`
|
||||
SourceMetadata *string `protobuf:"bytes,2,opt,name=source_metadata" json:"source_metadata,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesTransformResponse) Reset() { *m = ImagesTransformResponse{} }
|
||||
func (m *ImagesTransformResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesTransformResponse) ProtoMessage() {}
|
||||
|
||||
func (m *ImagesTransformResponse) GetImage() *ImageData {
|
||||
if m != nil {
|
||||
return m.Image
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *ImagesTransformResponse) GetSourceMetadata() string {
|
||||
if m != nil && m.SourceMetadata != nil {
|
||||
return *m.SourceMetadata
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type CompositeImageOptions struct {
|
||||
SourceIndex *int32 `protobuf:"varint,1,req,name=source_index" json:"source_index,omitempty"`
|
||||
XOffset *int32 `protobuf:"varint,2,req,name=x_offset" json:"x_offset,omitempty"`
|
||||
YOffset *int32 `protobuf:"varint,3,req,name=y_offset" json:"y_offset,omitempty"`
|
||||
Opacity *float32 `protobuf:"fixed32,4,req,name=opacity" json:"opacity,omitempty"`
|
||||
Anchor *CompositeImageOptions_ANCHOR `protobuf:"varint,5,req,name=anchor,enum=appengine.CompositeImageOptions_ANCHOR" json:"anchor,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CompositeImageOptions) Reset() { *m = CompositeImageOptions{} }
|
||||
func (m *CompositeImageOptions) String() string { return proto.CompactTextString(m) }
|
||||
func (*CompositeImageOptions) ProtoMessage() {}
|
||||
|
||||
func (m *CompositeImageOptions) GetSourceIndex() int32 {
|
||||
if m != nil && m.SourceIndex != nil {
|
||||
return *m.SourceIndex
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *CompositeImageOptions) GetXOffset() int32 {
|
||||
if m != nil && m.XOffset != nil {
|
||||
return *m.XOffset
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *CompositeImageOptions) GetYOffset() int32 {
|
||||
if m != nil && m.YOffset != nil {
|
||||
return *m.YOffset
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *CompositeImageOptions) GetOpacity() float32 {
|
||||
if m != nil && m.Opacity != nil {
|
||||
return *m.Opacity
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *CompositeImageOptions) GetAnchor() CompositeImageOptions_ANCHOR {
|
||||
if m != nil && m.Anchor != nil {
|
||||
return *m.Anchor
|
||||
}
|
||||
return CompositeImageOptions_TOP_LEFT
|
||||
}
|
||||
|
||||
type ImagesCanvas struct {
|
||||
Width *int32 `protobuf:"varint,1,req,name=width" json:"width,omitempty"`
|
||||
Height *int32 `protobuf:"varint,2,req,name=height" json:"height,omitempty"`
|
||||
Output *OutputSettings `protobuf:"bytes,3,req,name=output" json:"output,omitempty"`
|
||||
Color *int32 `protobuf:"varint,4,opt,name=color,def=-1" json:"color,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesCanvas) Reset() { *m = ImagesCanvas{} }
|
||||
func (m *ImagesCanvas) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesCanvas) ProtoMessage() {}
|
||||
|
||||
const Default_ImagesCanvas_Color int32 = -1
|
||||
|
||||
func (m *ImagesCanvas) GetWidth() int32 {
|
||||
if m != nil && m.Width != nil {
|
||||
return *m.Width
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *ImagesCanvas) GetHeight() int32 {
|
||||
if m != nil && m.Height != nil {
|
||||
return *m.Height
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *ImagesCanvas) GetOutput() *OutputSettings {
|
||||
if m != nil {
|
||||
return m.Output
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *ImagesCanvas) GetColor() int32 {
|
||||
if m != nil && m.Color != nil {
|
||||
return *m.Color
|
||||
}
|
||||
return Default_ImagesCanvas_Color
|
||||
}
|
||||
|
||||
type ImagesCompositeRequest struct {
|
||||
Image []*ImageData `protobuf:"bytes,1,rep,name=image" json:"image,omitempty"`
|
||||
Options []*CompositeImageOptions `protobuf:"bytes,2,rep,name=options" json:"options,omitempty"`
|
||||
Canvas *ImagesCanvas `protobuf:"bytes,3,req,name=canvas" json:"canvas,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesCompositeRequest) Reset() { *m = ImagesCompositeRequest{} }
|
||||
func (m *ImagesCompositeRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesCompositeRequest) ProtoMessage() {}
|
||||
|
||||
func (m *ImagesCompositeRequest) GetImage() []*ImageData {
|
||||
if m != nil {
|
||||
return m.Image
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *ImagesCompositeRequest) GetOptions() []*CompositeImageOptions {
|
||||
if m != nil {
|
||||
return m.Options
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *ImagesCompositeRequest) GetCanvas() *ImagesCanvas {
|
||||
if m != nil {
|
||||
return m.Canvas
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type ImagesCompositeResponse struct {
|
||||
Image *ImageData `protobuf:"bytes,1,req,name=image" json:"image,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesCompositeResponse) Reset() { *m = ImagesCompositeResponse{} }
|
||||
func (m *ImagesCompositeResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesCompositeResponse) ProtoMessage() {}
|
||||
|
||||
func (m *ImagesCompositeResponse) GetImage() *ImageData {
|
||||
if m != nil {
|
||||
return m.Image
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type ImagesHistogramRequest struct {
|
||||
Image *ImageData `protobuf:"bytes,1,req,name=image" json:"image,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesHistogramRequest) Reset() { *m = ImagesHistogramRequest{} }
|
||||
func (m *ImagesHistogramRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesHistogramRequest) ProtoMessage() {}
|
||||
|
||||
func (m *ImagesHistogramRequest) GetImage() *ImageData {
|
||||
if m != nil {
|
||||
return m.Image
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type ImagesHistogram struct {
|
||||
Red []int32 `protobuf:"varint,1,rep,name=red" json:"red,omitempty"`
|
||||
Green []int32 `protobuf:"varint,2,rep,name=green" json:"green,omitempty"`
|
||||
Blue []int32 `protobuf:"varint,3,rep,name=blue" json:"blue,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesHistogram) Reset() { *m = ImagesHistogram{} }
|
||||
func (m *ImagesHistogram) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesHistogram) ProtoMessage() {}
|
||||
|
||||
func (m *ImagesHistogram) GetRed() []int32 {
|
||||
if m != nil {
|
||||
return m.Red
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *ImagesHistogram) GetGreen() []int32 {
|
||||
if m != nil {
|
||||
return m.Green
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *ImagesHistogram) GetBlue() []int32 {
|
||||
if m != nil {
|
||||
return m.Blue
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type ImagesHistogramResponse struct {
|
||||
Histogram *ImagesHistogram `protobuf:"bytes,1,req,name=histogram" json:"histogram,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesHistogramResponse) Reset() { *m = ImagesHistogramResponse{} }
|
||||
func (m *ImagesHistogramResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesHistogramResponse) ProtoMessage() {}
|
||||
|
||||
func (m *ImagesHistogramResponse) GetHistogram() *ImagesHistogram {
|
||||
if m != nil {
|
||||
return m.Histogram
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type ImagesGetUrlBaseRequest struct {
|
||||
BlobKey *string `protobuf:"bytes,1,req,name=blob_key" json:"blob_key,omitempty"`
|
||||
CreateSecureUrl *bool `protobuf:"varint,2,opt,name=create_secure_url,def=0" json:"create_secure_url,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesGetUrlBaseRequest) Reset() { *m = ImagesGetUrlBaseRequest{} }
|
||||
func (m *ImagesGetUrlBaseRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesGetUrlBaseRequest) ProtoMessage() {}
|
||||
|
||||
const Default_ImagesGetUrlBaseRequest_CreateSecureUrl bool = false
|
||||
|
||||
func (m *ImagesGetUrlBaseRequest) GetBlobKey() string {
|
||||
if m != nil && m.BlobKey != nil {
|
||||
return *m.BlobKey
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *ImagesGetUrlBaseRequest) GetCreateSecureUrl() bool {
|
||||
if m != nil && m.CreateSecureUrl != nil {
|
||||
return *m.CreateSecureUrl
|
||||
}
|
||||
return Default_ImagesGetUrlBaseRequest_CreateSecureUrl
|
||||
}
|
||||
|
||||
type ImagesGetUrlBaseResponse struct {
|
||||
Url *string `protobuf:"bytes,1,req,name=url" json:"url,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesGetUrlBaseResponse) Reset() { *m = ImagesGetUrlBaseResponse{} }
|
||||
func (m *ImagesGetUrlBaseResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesGetUrlBaseResponse) ProtoMessage() {}
|
||||
|
||||
func (m *ImagesGetUrlBaseResponse) GetUrl() string {
|
||||
if m != nil && m.Url != nil {
|
||||
return *m.Url
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type ImagesDeleteUrlBaseRequest struct {
|
||||
BlobKey *string `protobuf:"bytes,1,req,name=blob_key" json:"blob_key,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesDeleteUrlBaseRequest) Reset() { *m = ImagesDeleteUrlBaseRequest{} }
|
||||
func (m *ImagesDeleteUrlBaseRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesDeleteUrlBaseRequest) ProtoMessage() {}
|
||||
|
||||
func (m *ImagesDeleteUrlBaseRequest) GetBlobKey() string {
|
||||
if m != nil && m.BlobKey != nil {
|
||||
return *m.BlobKey
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type ImagesDeleteUrlBaseResponse struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ImagesDeleteUrlBaseResponse) Reset() { *m = ImagesDeleteUrlBaseResponse{} }
|
||||
func (m *ImagesDeleteUrlBaseResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*ImagesDeleteUrlBaseResponse) ProtoMessage() {}
|
||||
|
||||
func init() {
|
||||
}
|
162
vendor/google.golang.org/appengine/internal/image/images_service.proto
generated
vendored
Normal file
162
vendor/google.golang.org/appengine/internal/image/images_service.proto
generated
vendored
Normal file
@@ -0,0 +1,162 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "image";
|
||||
|
||||
package appengine;
|
||||
|
||||
message ImagesServiceError {
|
||||
enum ErrorCode {
|
||||
UNSPECIFIED_ERROR = 1;
|
||||
BAD_TRANSFORM_DATA = 2;
|
||||
NOT_IMAGE = 3;
|
||||
BAD_IMAGE_DATA = 4;
|
||||
IMAGE_TOO_LARGE = 5;
|
||||
INVALID_BLOB_KEY = 6;
|
||||
ACCESS_DENIED = 7;
|
||||
OBJECT_NOT_FOUND = 8;
|
||||
}
|
||||
}
|
||||
|
||||
message ImagesServiceTransform {
|
||||
enum Type {
|
||||
RESIZE = 1;
|
||||
ROTATE = 2;
|
||||
HORIZONTAL_FLIP = 3;
|
||||
VERTICAL_FLIP = 4;
|
||||
CROP = 5;
|
||||
IM_FEELING_LUCKY = 6;
|
||||
}
|
||||
}
|
||||
|
||||
message Transform {
|
||||
optional int32 width = 1;
|
||||
optional int32 height = 2;
|
||||
optional bool crop_to_fit = 11 [default = false];
|
||||
optional float crop_offset_x = 12 [default = 0.5];
|
||||
optional float crop_offset_y = 13 [default = 0.5];
|
||||
|
||||
optional int32 rotate = 3 [default = 0];
|
||||
|
||||
optional bool horizontal_flip = 4 [default = false];
|
||||
|
||||
optional bool vertical_flip = 5 [default = false];
|
||||
|
||||
optional float crop_left_x = 6 [default = 0.0];
|
||||
optional float crop_top_y = 7 [default = 0.0];
|
||||
optional float crop_right_x = 8 [default = 1.0];
|
||||
optional float crop_bottom_y = 9 [default = 1.0];
|
||||
|
||||
optional bool autolevels = 10 [default = false];
|
||||
|
||||
optional bool allow_stretch = 14 [default = false];
|
||||
}
|
||||
|
||||
message ImageData {
|
||||
required bytes content = 1 [ctype=CORD];
|
||||
optional string blob_key = 2;
|
||||
|
||||
optional int32 width = 3;
|
||||
optional int32 height = 4;
|
||||
}
|
||||
|
||||
message InputSettings {
|
||||
enum ORIENTATION_CORRECTION_TYPE {
|
||||
UNCHANGED_ORIENTATION = 0;
|
||||
CORRECT_ORIENTATION = 1;
|
||||
}
|
||||
optional ORIENTATION_CORRECTION_TYPE correct_exif_orientation = 1
|
||||
[default=UNCHANGED_ORIENTATION];
|
||||
optional bool parse_metadata = 2 [default=false];
|
||||
optional int32 transparent_substitution_rgb = 3;
|
||||
}
|
||||
|
||||
message OutputSettings {
|
||||
enum MIME_TYPE {
|
||||
PNG = 0;
|
||||
JPEG = 1;
|
||||
WEBP = 2;
|
||||
}
|
||||
|
||||
optional MIME_TYPE mime_type = 1 [default=PNG];
|
||||
optional int32 quality = 2;
|
||||
}
|
||||
|
||||
message ImagesTransformRequest {
|
||||
required ImageData image = 1;
|
||||
repeated Transform transform = 2;
|
||||
required OutputSettings output = 3;
|
||||
optional InputSettings input = 4;
|
||||
}
|
||||
|
||||
message ImagesTransformResponse {
|
||||
required ImageData image = 1;
|
||||
optional string source_metadata = 2;
|
||||
}
|
||||
|
||||
message CompositeImageOptions {
|
||||
required int32 source_index = 1;
|
||||
required int32 x_offset = 2;
|
||||
required int32 y_offset = 3;
|
||||
required float opacity = 4;
|
||||
|
||||
enum ANCHOR {
|
||||
TOP_LEFT = 0;
|
||||
TOP = 1;
|
||||
TOP_RIGHT = 2;
|
||||
LEFT = 3;
|
||||
CENTER = 4;
|
||||
RIGHT = 5;
|
||||
BOTTOM_LEFT = 6;
|
||||
BOTTOM = 7;
|
||||
BOTTOM_RIGHT = 8;
|
||||
}
|
||||
|
||||
required ANCHOR anchor = 5;
|
||||
}
|
||||
|
||||
message ImagesCanvas {
|
||||
required int32 width = 1;
|
||||
required int32 height = 2;
|
||||
required OutputSettings output = 3;
|
||||
optional int32 color = 4 [default=-1];
|
||||
}
|
||||
|
||||
message ImagesCompositeRequest {
|
||||
repeated ImageData image = 1;
|
||||
repeated CompositeImageOptions options = 2;
|
||||
required ImagesCanvas canvas = 3;
|
||||
}
|
||||
|
||||
message ImagesCompositeResponse {
|
||||
required ImageData image = 1;
|
||||
}
|
||||
|
||||
message ImagesHistogramRequest {
|
||||
required ImageData image = 1;
|
||||
}
|
||||
|
||||
message ImagesHistogram {
|
||||
repeated int32 red = 1;
|
||||
repeated int32 green = 2;
|
||||
repeated int32 blue = 3;
|
||||
}
|
||||
|
||||
message ImagesHistogramResponse {
|
||||
required ImagesHistogram histogram = 1;
|
||||
}
|
||||
|
||||
message ImagesGetUrlBaseRequest {
|
||||
required string blob_key = 1;
|
||||
|
||||
optional bool create_secure_url = 2 [default = false];
|
||||
}
|
||||
|
||||
message ImagesGetUrlBaseResponse {
|
||||
required string url = 1;
|
||||
}
|
||||
|
||||
message ImagesDeleteUrlBaseRequest {
|
||||
required string blob_key = 1;
|
||||
}
|
||||
|
||||
message ImagesDeleteUrlBaseResponse {
|
||||
}
|
110
vendor/google.golang.org/appengine/internal/internal.go
generated
vendored
Normal file
110
vendor/google.golang.org/appengine/internal/internal.go
generated
vendored
Normal file
@@ -0,0 +1,110 @@
|
||||
// Copyright 2011 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
// Package internal provides support for package appengine.
|
||||
//
|
||||
// Programs should not use this package directly. Its API is not stable.
|
||||
// Use packages appengine and appengine/* instead.
|
||||
package internal
|
||||
|
||||
import (
|
||||
"fmt"
|
||||
|
||||
"github.com/golang/protobuf/proto"
|
||||
|
||||
remotepb "google.golang.org/appengine/internal/remote_api"
|
||||
)
|
||||
|
||||
// errorCodeMaps is a map of service name to the error code map for the service.
|
||||
var errorCodeMaps = make(map[string]map[int32]string)
|
||||
|
||||
// RegisterErrorCodeMap is called from API implementations to register their
|
||||
// error code map. This should only be called from init functions.
|
||||
func RegisterErrorCodeMap(service string, m map[int32]string) {
|
||||
errorCodeMaps[service] = m
|
||||
}
|
||||
|
||||
type timeoutCodeKey struct {
|
||||
service string
|
||||
code int32
|
||||
}
|
||||
|
||||
// timeoutCodes is the set of service+code pairs that represent timeouts.
|
||||
var timeoutCodes = make(map[timeoutCodeKey]bool)
|
||||
|
||||
func RegisterTimeoutErrorCode(service string, code int32) {
|
||||
timeoutCodes[timeoutCodeKey{service, code}] = true
|
||||
}
|
||||
|
||||
// APIError is the type returned by appengine.Context's Call method
|
||||
// when an API call fails in an API-specific way. This may be, for instance,
|
||||
// a taskqueue API call failing with TaskQueueServiceError::UNKNOWN_QUEUE.
|
||||
type APIError struct {
|
||||
Service string
|
||||
Detail string
|
||||
Code int32 // API-specific error code
|
||||
}
|
||||
|
||||
func (e *APIError) Error() string {
|
||||
if e.Code == 0 {
|
||||
if e.Detail == "" {
|
||||
return "APIError <empty>"
|
||||
}
|
||||
return e.Detail
|
||||
}
|
||||
s := fmt.Sprintf("API error %d", e.Code)
|
||||
if m, ok := errorCodeMaps[e.Service]; ok {
|
||||
s += " (" + e.Service + ": " + m[e.Code] + ")"
|
||||
} else {
|
||||
// Shouldn't happen, but provide a bit more detail if it does.
|
||||
s = e.Service + " " + s
|
||||
}
|
||||
if e.Detail != "" {
|
||||
s += ": " + e.Detail
|
||||
}
|
||||
return s
|
||||
}
|
||||
|
||||
func (e *APIError) IsTimeout() bool {
|
||||
return timeoutCodes[timeoutCodeKey{e.Service, e.Code}]
|
||||
}
|
||||
|
||||
// CallError is the type returned by appengine.Context's Call method when an
|
||||
// API call fails in a generic way, such as RpcError::CAPABILITY_DISABLED.
|
||||
type CallError struct {
|
||||
Detail string
|
||||
Code int32
|
||||
// TODO: Remove this if we get a distinguishable error code.
|
||||
Timeout bool
|
||||
}
|
||||
|
||||
func (e *CallError) Error() string {
|
||||
var msg string
|
||||
switch remotepb.RpcError_ErrorCode(e.Code) {
|
||||
case remotepb.RpcError_UNKNOWN:
|
||||
return e.Detail
|
||||
case remotepb.RpcError_OVER_QUOTA:
|
||||
msg = "Over quota"
|
||||
case remotepb.RpcError_CAPABILITY_DISABLED:
|
||||
msg = "Capability disabled"
|
||||
case remotepb.RpcError_CANCELLED:
|
||||
msg = "Canceled"
|
||||
default:
|
||||
msg = fmt.Sprintf("Call error %d", e.Code)
|
||||
}
|
||||
s := msg + ": " + e.Detail
|
||||
if e.Timeout {
|
||||
s += " (timeout)"
|
||||
}
|
||||
return s
|
||||
}
|
||||
|
||||
func (e *CallError) IsTimeout() bool {
|
||||
return e.Timeout
|
||||
}
|
||||
|
||||
// NamespaceMods is a map from API service to a function that will mutate an RPC request to attach a namespace.
|
||||
// The function should be prepared to be called on the same message more than once; it should only modify the
|
||||
// RPC request the first time.
|
||||
var NamespaceMods = make(map[string]func(m proto.Message, namespace string))
|
60
vendor/google.golang.org/appengine/internal/internal_vm_test.go
generated
vendored
Normal file
60
vendor/google.golang.org/appengine/internal/internal_vm_test.go
generated
vendored
Normal file
@@ -0,0 +1,60 @@
|
||||
// Copyright 2014 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
// +build !appengine
|
||||
|
||||
package internal
|
||||
|
||||
import (
|
||||
"io"
|
||||
"io/ioutil"
|
||||
"net/http"
|
||||
"net/http/httptest"
|
||||
"testing"
|
||||
)
|
||||
|
||||
func TestInstallingHealthChecker(t *testing.T) {
|
||||
try := func(desc string, mux *http.ServeMux, wantCode int, wantBody string) {
|
||||
installHealthChecker(mux)
|
||||
srv := httptest.NewServer(mux)
|
||||
defer srv.Close()
|
||||
|
||||
resp, err := http.Get(srv.URL + "/_ah/health")
|
||||
if err != nil {
|
||||
t.Errorf("%s: http.Get: %v", desc, err)
|
||||
return
|
||||
}
|
||||
defer resp.Body.Close()
|
||||
body, err := ioutil.ReadAll(resp.Body)
|
||||
if err != nil {
|
||||
t.Errorf("%s: reading body: %v", desc, err)
|
||||
return
|
||||
}
|
||||
|
||||
if resp.StatusCode != wantCode {
|
||||
t.Errorf("%s: got HTTP %d, want %d", desc, resp.StatusCode, wantCode)
|
||||
return
|
||||
}
|
||||
if wantBody != "" && string(body) != wantBody {
|
||||
t.Errorf("%s: got HTTP body %q, want %q", desc, body, wantBody)
|
||||
return
|
||||
}
|
||||
}
|
||||
|
||||
// If there's no handlers, or only a root handler, a health checker should be installed.
|
||||
try("empty mux", http.NewServeMux(), 200, "ok")
|
||||
mux := http.NewServeMux()
|
||||
mux.HandleFunc("/", func(w http.ResponseWriter, r *http.Request) {
|
||||
io.WriteString(w, "root handler")
|
||||
})
|
||||
try("mux with root handler", mux, 200, "ok")
|
||||
|
||||
// If there's a custom health check handler, one should not be installed.
|
||||
mux = http.NewServeMux()
|
||||
mux.HandleFunc("/_ah/health", func(w http.ResponseWriter, r *http.Request) {
|
||||
w.WriteHeader(418)
|
||||
io.WriteString(w, "I'm short and stout!")
|
||||
})
|
||||
try("mux with custom health checker", mux, 418, "I'm short and stout!")
|
||||
}
|
899
vendor/google.golang.org/appengine/internal/log/log_service.pb.go
generated
vendored
Normal file
899
vendor/google.golang.org/appengine/internal/log/log_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,899 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/log/log_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package log is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/log/log_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
LogServiceError
|
||||
UserAppLogLine
|
||||
UserAppLogGroup
|
||||
FlushRequest
|
||||
SetStatusRequest
|
||||
LogOffset
|
||||
LogLine
|
||||
RequestLog
|
||||
LogModuleVersion
|
||||
LogReadRequest
|
||||
LogReadResponse
|
||||
LogUsageRecord
|
||||
LogUsageRequest
|
||||
LogUsageResponse
|
||||
*/
|
||||
package log
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type LogServiceError_ErrorCode int32
|
||||
|
||||
const (
|
||||
LogServiceError_OK LogServiceError_ErrorCode = 0
|
||||
LogServiceError_INVALID_REQUEST LogServiceError_ErrorCode = 1
|
||||
LogServiceError_STORAGE_ERROR LogServiceError_ErrorCode = 2
|
||||
)
|
||||
|
||||
var LogServiceError_ErrorCode_name = map[int32]string{
|
||||
0: "OK",
|
||||
1: "INVALID_REQUEST",
|
||||
2: "STORAGE_ERROR",
|
||||
}
|
||||
var LogServiceError_ErrorCode_value = map[string]int32{
|
||||
"OK": 0,
|
||||
"INVALID_REQUEST": 1,
|
||||
"STORAGE_ERROR": 2,
|
||||
}
|
||||
|
||||
func (x LogServiceError_ErrorCode) Enum() *LogServiceError_ErrorCode {
|
||||
p := new(LogServiceError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x LogServiceError_ErrorCode) String() string {
|
||||
return proto.EnumName(LogServiceError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *LogServiceError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(LogServiceError_ErrorCode_value, data, "LogServiceError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = LogServiceError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type LogServiceError struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *LogServiceError) Reset() { *m = LogServiceError{} }
|
||||
func (m *LogServiceError) String() string { return proto.CompactTextString(m) }
|
||||
func (*LogServiceError) ProtoMessage() {}
|
||||
|
||||
type UserAppLogLine struct {
|
||||
TimestampUsec *int64 `protobuf:"varint,1,req,name=timestamp_usec" json:"timestamp_usec,omitempty"`
|
||||
Level *int64 `protobuf:"varint,2,req,name=level" json:"level,omitempty"`
|
||||
Message *string `protobuf:"bytes,3,req,name=message" json:"message,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *UserAppLogLine) Reset() { *m = UserAppLogLine{} }
|
||||
func (m *UserAppLogLine) String() string { return proto.CompactTextString(m) }
|
||||
func (*UserAppLogLine) ProtoMessage() {}
|
||||
|
||||
func (m *UserAppLogLine) GetTimestampUsec() int64 {
|
||||
if m != nil && m.TimestampUsec != nil {
|
||||
return *m.TimestampUsec
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *UserAppLogLine) GetLevel() int64 {
|
||||
if m != nil && m.Level != nil {
|
||||
return *m.Level
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *UserAppLogLine) GetMessage() string {
|
||||
if m != nil && m.Message != nil {
|
||||
return *m.Message
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type UserAppLogGroup struct {
|
||||
LogLine []*UserAppLogLine `protobuf:"bytes,2,rep,name=log_line" json:"log_line,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *UserAppLogGroup) Reset() { *m = UserAppLogGroup{} }
|
||||
func (m *UserAppLogGroup) String() string { return proto.CompactTextString(m) }
|
||||
func (*UserAppLogGroup) ProtoMessage() {}
|
||||
|
||||
func (m *UserAppLogGroup) GetLogLine() []*UserAppLogLine {
|
||||
if m != nil {
|
||||
return m.LogLine
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type FlushRequest struct {
|
||||
Logs []byte `protobuf:"bytes,1,opt,name=logs" json:"logs,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *FlushRequest) Reset() { *m = FlushRequest{} }
|
||||
func (m *FlushRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*FlushRequest) ProtoMessage() {}
|
||||
|
||||
func (m *FlushRequest) GetLogs() []byte {
|
||||
if m != nil {
|
||||
return m.Logs
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type SetStatusRequest struct {
|
||||
Status *string `protobuf:"bytes,1,req,name=status" json:"status,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *SetStatusRequest) Reset() { *m = SetStatusRequest{} }
|
||||
func (m *SetStatusRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*SetStatusRequest) ProtoMessage() {}
|
||||
|
||||
func (m *SetStatusRequest) GetStatus() string {
|
||||
if m != nil && m.Status != nil {
|
||||
return *m.Status
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type LogOffset struct {
|
||||
RequestId []byte `protobuf:"bytes,1,opt,name=request_id" json:"request_id,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *LogOffset) Reset() { *m = LogOffset{} }
|
||||
func (m *LogOffset) String() string { return proto.CompactTextString(m) }
|
||||
func (*LogOffset) ProtoMessage() {}
|
||||
|
||||
func (m *LogOffset) GetRequestId() []byte {
|
||||
if m != nil {
|
||||
return m.RequestId
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type LogLine struct {
|
||||
Time *int64 `protobuf:"varint,1,req,name=time" json:"time,omitempty"`
|
||||
Level *int32 `protobuf:"varint,2,req,name=level" json:"level,omitempty"`
|
||||
LogMessage *string `protobuf:"bytes,3,req,name=log_message" json:"log_message,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *LogLine) Reset() { *m = LogLine{} }
|
||||
func (m *LogLine) String() string { return proto.CompactTextString(m) }
|
||||
func (*LogLine) ProtoMessage() {}
|
||||
|
||||
func (m *LogLine) GetTime() int64 {
|
||||
if m != nil && m.Time != nil {
|
||||
return *m.Time
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogLine) GetLevel() int32 {
|
||||
if m != nil && m.Level != nil {
|
||||
return *m.Level
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogLine) GetLogMessage() string {
|
||||
if m != nil && m.LogMessage != nil {
|
||||
return *m.LogMessage
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type RequestLog struct {
|
||||
AppId *string `protobuf:"bytes,1,req,name=app_id" json:"app_id,omitempty"`
|
||||
ModuleId *string `protobuf:"bytes,37,opt,name=module_id,def=default" json:"module_id,omitempty"`
|
||||
VersionId *string `protobuf:"bytes,2,req,name=version_id" json:"version_id,omitempty"`
|
||||
RequestId []byte `protobuf:"bytes,3,req,name=request_id" json:"request_id,omitempty"`
|
||||
Offset *LogOffset `protobuf:"bytes,35,opt,name=offset" json:"offset,omitempty"`
|
||||
Ip *string `protobuf:"bytes,4,req,name=ip" json:"ip,omitempty"`
|
||||
Nickname *string `protobuf:"bytes,5,opt,name=nickname" json:"nickname,omitempty"`
|
||||
StartTime *int64 `protobuf:"varint,6,req,name=start_time" json:"start_time,omitempty"`
|
||||
EndTime *int64 `protobuf:"varint,7,req,name=end_time" json:"end_time,omitempty"`
|
||||
Latency *int64 `protobuf:"varint,8,req,name=latency" json:"latency,omitempty"`
|
||||
Mcycles *int64 `protobuf:"varint,9,req,name=mcycles" json:"mcycles,omitempty"`
|
||||
Method *string `protobuf:"bytes,10,req,name=method" json:"method,omitempty"`
|
||||
Resource *string `protobuf:"bytes,11,req,name=resource" json:"resource,omitempty"`
|
||||
HttpVersion *string `protobuf:"bytes,12,req,name=http_version" json:"http_version,omitempty"`
|
||||
Status *int32 `protobuf:"varint,13,req,name=status" json:"status,omitempty"`
|
||||
ResponseSize *int64 `protobuf:"varint,14,req,name=response_size" json:"response_size,omitempty"`
|
||||
Referrer *string `protobuf:"bytes,15,opt,name=referrer" json:"referrer,omitempty"`
|
||||
UserAgent *string `protobuf:"bytes,16,opt,name=user_agent" json:"user_agent,omitempty"`
|
||||
UrlMapEntry *string `protobuf:"bytes,17,req,name=url_map_entry" json:"url_map_entry,omitempty"`
|
||||
Combined *string `protobuf:"bytes,18,req,name=combined" json:"combined,omitempty"`
|
||||
ApiMcycles *int64 `protobuf:"varint,19,opt,name=api_mcycles" json:"api_mcycles,omitempty"`
|
||||
Host *string `protobuf:"bytes,20,opt,name=host" json:"host,omitempty"`
|
||||
Cost *float64 `protobuf:"fixed64,21,opt,name=cost" json:"cost,omitempty"`
|
||||
TaskQueueName *string `protobuf:"bytes,22,opt,name=task_queue_name" json:"task_queue_name,omitempty"`
|
||||
TaskName *string `protobuf:"bytes,23,opt,name=task_name" json:"task_name,omitempty"`
|
||||
WasLoadingRequest *bool `protobuf:"varint,24,opt,name=was_loading_request" json:"was_loading_request,omitempty"`
|
||||
PendingTime *int64 `protobuf:"varint,25,opt,name=pending_time" json:"pending_time,omitempty"`
|
||||
ReplicaIndex *int32 `protobuf:"varint,26,opt,name=replica_index,def=-1" json:"replica_index,omitempty"`
|
||||
Finished *bool `protobuf:"varint,27,opt,name=finished,def=1" json:"finished,omitempty"`
|
||||
CloneKey []byte `protobuf:"bytes,28,opt,name=clone_key" json:"clone_key,omitempty"`
|
||||
Line []*LogLine `protobuf:"bytes,29,rep,name=line" json:"line,omitempty"`
|
||||
LinesIncomplete *bool `protobuf:"varint,36,opt,name=lines_incomplete" json:"lines_incomplete,omitempty"`
|
||||
AppEngineRelease []byte `protobuf:"bytes,38,opt,name=app_engine_release" json:"app_engine_release,omitempty"`
|
||||
ExitReason *int32 `protobuf:"varint,30,opt,name=exit_reason" json:"exit_reason,omitempty"`
|
||||
WasThrottledForTime *bool `protobuf:"varint,31,opt,name=was_throttled_for_time" json:"was_throttled_for_time,omitempty"`
|
||||
WasThrottledForRequests *bool `protobuf:"varint,32,opt,name=was_throttled_for_requests" json:"was_throttled_for_requests,omitempty"`
|
||||
ThrottledTime *int64 `protobuf:"varint,33,opt,name=throttled_time" json:"throttled_time,omitempty"`
|
||||
ServerName []byte `protobuf:"bytes,34,opt,name=server_name" json:"server_name,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *RequestLog) Reset() { *m = RequestLog{} }
|
||||
func (m *RequestLog) String() string { return proto.CompactTextString(m) }
|
||||
func (*RequestLog) ProtoMessage() {}
|
||||
|
||||
const Default_RequestLog_ModuleId string = "default"
|
||||
const Default_RequestLog_ReplicaIndex int32 = -1
|
||||
const Default_RequestLog_Finished bool = true
|
||||
|
||||
func (m *RequestLog) GetAppId() string {
|
||||
if m != nil && m.AppId != nil {
|
||||
return *m.AppId
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetModuleId() string {
|
||||
if m != nil && m.ModuleId != nil {
|
||||
return *m.ModuleId
|
||||
}
|
||||
return Default_RequestLog_ModuleId
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetVersionId() string {
|
||||
if m != nil && m.VersionId != nil {
|
||||
return *m.VersionId
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetRequestId() []byte {
|
||||
if m != nil {
|
||||
return m.RequestId
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetOffset() *LogOffset {
|
||||
if m != nil {
|
||||
return m.Offset
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetIp() string {
|
||||
if m != nil && m.Ip != nil {
|
||||
return *m.Ip
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetNickname() string {
|
||||
if m != nil && m.Nickname != nil {
|
||||
return *m.Nickname
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetStartTime() int64 {
|
||||
if m != nil && m.StartTime != nil {
|
||||
return *m.StartTime
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetEndTime() int64 {
|
||||
if m != nil && m.EndTime != nil {
|
||||
return *m.EndTime
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetLatency() int64 {
|
||||
if m != nil && m.Latency != nil {
|
||||
return *m.Latency
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetMcycles() int64 {
|
||||
if m != nil && m.Mcycles != nil {
|
||||
return *m.Mcycles
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetMethod() string {
|
||||
if m != nil && m.Method != nil {
|
||||
return *m.Method
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetResource() string {
|
||||
if m != nil && m.Resource != nil {
|
||||
return *m.Resource
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetHttpVersion() string {
|
||||
if m != nil && m.HttpVersion != nil {
|
||||
return *m.HttpVersion
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetStatus() int32 {
|
||||
if m != nil && m.Status != nil {
|
||||
return *m.Status
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetResponseSize() int64 {
|
||||
if m != nil && m.ResponseSize != nil {
|
||||
return *m.ResponseSize
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetReferrer() string {
|
||||
if m != nil && m.Referrer != nil {
|
||||
return *m.Referrer
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetUserAgent() string {
|
||||
if m != nil && m.UserAgent != nil {
|
||||
return *m.UserAgent
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetUrlMapEntry() string {
|
||||
if m != nil && m.UrlMapEntry != nil {
|
||||
return *m.UrlMapEntry
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetCombined() string {
|
||||
if m != nil && m.Combined != nil {
|
||||
return *m.Combined
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetApiMcycles() int64 {
|
||||
if m != nil && m.ApiMcycles != nil {
|
||||
return *m.ApiMcycles
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetHost() string {
|
||||
if m != nil && m.Host != nil {
|
||||
return *m.Host
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetCost() float64 {
|
||||
if m != nil && m.Cost != nil {
|
||||
return *m.Cost
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetTaskQueueName() string {
|
||||
if m != nil && m.TaskQueueName != nil {
|
||||
return *m.TaskQueueName
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetTaskName() string {
|
||||
if m != nil && m.TaskName != nil {
|
||||
return *m.TaskName
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetWasLoadingRequest() bool {
|
||||
if m != nil && m.WasLoadingRequest != nil {
|
||||
return *m.WasLoadingRequest
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetPendingTime() int64 {
|
||||
if m != nil && m.PendingTime != nil {
|
||||
return *m.PendingTime
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetReplicaIndex() int32 {
|
||||
if m != nil && m.ReplicaIndex != nil {
|
||||
return *m.ReplicaIndex
|
||||
}
|
||||
return Default_RequestLog_ReplicaIndex
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetFinished() bool {
|
||||
if m != nil && m.Finished != nil {
|
||||
return *m.Finished
|
||||
}
|
||||
return Default_RequestLog_Finished
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetCloneKey() []byte {
|
||||
if m != nil {
|
||||
return m.CloneKey
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetLine() []*LogLine {
|
||||
if m != nil {
|
||||
return m.Line
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetLinesIncomplete() bool {
|
||||
if m != nil && m.LinesIncomplete != nil {
|
||||
return *m.LinesIncomplete
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetAppEngineRelease() []byte {
|
||||
if m != nil {
|
||||
return m.AppEngineRelease
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetExitReason() int32 {
|
||||
if m != nil && m.ExitReason != nil {
|
||||
return *m.ExitReason
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetWasThrottledForTime() bool {
|
||||
if m != nil && m.WasThrottledForTime != nil {
|
||||
return *m.WasThrottledForTime
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetWasThrottledForRequests() bool {
|
||||
if m != nil && m.WasThrottledForRequests != nil {
|
||||
return *m.WasThrottledForRequests
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetThrottledTime() int64 {
|
||||
if m != nil && m.ThrottledTime != nil {
|
||||
return *m.ThrottledTime
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *RequestLog) GetServerName() []byte {
|
||||
if m != nil {
|
||||
return m.ServerName
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type LogModuleVersion struct {
|
||||
ModuleId *string `protobuf:"bytes,1,opt,name=module_id,def=default" json:"module_id,omitempty"`
|
||||
VersionId *string `protobuf:"bytes,2,opt,name=version_id" json:"version_id,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *LogModuleVersion) Reset() { *m = LogModuleVersion{} }
|
||||
func (m *LogModuleVersion) String() string { return proto.CompactTextString(m) }
|
||||
func (*LogModuleVersion) ProtoMessage() {}
|
||||
|
||||
const Default_LogModuleVersion_ModuleId string = "default"
|
||||
|
||||
func (m *LogModuleVersion) GetModuleId() string {
|
||||
if m != nil && m.ModuleId != nil {
|
||||
return *m.ModuleId
|
||||
}
|
||||
return Default_LogModuleVersion_ModuleId
|
||||
}
|
||||
|
||||
func (m *LogModuleVersion) GetVersionId() string {
|
||||
if m != nil && m.VersionId != nil {
|
||||
return *m.VersionId
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type LogReadRequest struct {
|
||||
AppId *string `protobuf:"bytes,1,req,name=app_id" json:"app_id,omitempty"`
|
||||
VersionId []string `protobuf:"bytes,2,rep,name=version_id" json:"version_id,omitempty"`
|
||||
ModuleVersion []*LogModuleVersion `protobuf:"bytes,19,rep,name=module_version" json:"module_version,omitempty"`
|
||||
StartTime *int64 `protobuf:"varint,3,opt,name=start_time" json:"start_time,omitempty"`
|
||||
EndTime *int64 `protobuf:"varint,4,opt,name=end_time" json:"end_time,omitempty"`
|
||||
Offset *LogOffset `protobuf:"bytes,5,opt,name=offset" json:"offset,omitempty"`
|
||||
RequestId [][]byte `protobuf:"bytes,6,rep,name=request_id" json:"request_id,omitempty"`
|
||||
MinimumLogLevel *int32 `protobuf:"varint,7,opt,name=minimum_log_level" json:"minimum_log_level,omitempty"`
|
||||
IncludeIncomplete *bool `protobuf:"varint,8,opt,name=include_incomplete" json:"include_incomplete,omitempty"`
|
||||
Count *int64 `protobuf:"varint,9,opt,name=count" json:"count,omitempty"`
|
||||
CombinedLogRegex *string `protobuf:"bytes,14,opt,name=combined_log_regex" json:"combined_log_regex,omitempty"`
|
||||
HostRegex *string `protobuf:"bytes,15,opt,name=host_regex" json:"host_regex,omitempty"`
|
||||
ReplicaIndex *int32 `protobuf:"varint,16,opt,name=replica_index" json:"replica_index,omitempty"`
|
||||
IncludeAppLogs *bool `protobuf:"varint,10,opt,name=include_app_logs" json:"include_app_logs,omitempty"`
|
||||
AppLogsPerRequest *int32 `protobuf:"varint,17,opt,name=app_logs_per_request" json:"app_logs_per_request,omitempty"`
|
||||
IncludeHost *bool `protobuf:"varint,11,opt,name=include_host" json:"include_host,omitempty"`
|
||||
IncludeAll *bool `protobuf:"varint,12,opt,name=include_all" json:"include_all,omitempty"`
|
||||
CacheIterator *bool `protobuf:"varint,13,opt,name=cache_iterator" json:"cache_iterator,omitempty"`
|
||||
NumShards *int32 `protobuf:"varint,18,opt,name=num_shards" json:"num_shards,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) Reset() { *m = LogReadRequest{} }
|
||||
func (m *LogReadRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*LogReadRequest) ProtoMessage() {}
|
||||
|
||||
func (m *LogReadRequest) GetAppId() string {
|
||||
if m != nil && m.AppId != nil {
|
||||
return *m.AppId
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetVersionId() []string {
|
||||
if m != nil {
|
||||
return m.VersionId
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetModuleVersion() []*LogModuleVersion {
|
||||
if m != nil {
|
||||
return m.ModuleVersion
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetStartTime() int64 {
|
||||
if m != nil && m.StartTime != nil {
|
||||
return *m.StartTime
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetEndTime() int64 {
|
||||
if m != nil && m.EndTime != nil {
|
||||
return *m.EndTime
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetOffset() *LogOffset {
|
||||
if m != nil {
|
||||
return m.Offset
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetRequestId() [][]byte {
|
||||
if m != nil {
|
||||
return m.RequestId
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetMinimumLogLevel() int32 {
|
||||
if m != nil && m.MinimumLogLevel != nil {
|
||||
return *m.MinimumLogLevel
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetIncludeIncomplete() bool {
|
||||
if m != nil && m.IncludeIncomplete != nil {
|
||||
return *m.IncludeIncomplete
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetCount() int64 {
|
||||
if m != nil && m.Count != nil {
|
||||
return *m.Count
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetCombinedLogRegex() string {
|
||||
if m != nil && m.CombinedLogRegex != nil {
|
||||
return *m.CombinedLogRegex
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetHostRegex() string {
|
||||
if m != nil && m.HostRegex != nil {
|
||||
return *m.HostRegex
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetReplicaIndex() int32 {
|
||||
if m != nil && m.ReplicaIndex != nil {
|
||||
return *m.ReplicaIndex
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetIncludeAppLogs() bool {
|
||||
if m != nil && m.IncludeAppLogs != nil {
|
||||
return *m.IncludeAppLogs
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetAppLogsPerRequest() int32 {
|
||||
if m != nil && m.AppLogsPerRequest != nil {
|
||||
return *m.AppLogsPerRequest
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetIncludeHost() bool {
|
||||
if m != nil && m.IncludeHost != nil {
|
||||
return *m.IncludeHost
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetIncludeAll() bool {
|
||||
if m != nil && m.IncludeAll != nil {
|
||||
return *m.IncludeAll
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetCacheIterator() bool {
|
||||
if m != nil && m.CacheIterator != nil {
|
||||
return *m.CacheIterator
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *LogReadRequest) GetNumShards() int32 {
|
||||
if m != nil && m.NumShards != nil {
|
||||
return *m.NumShards
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type LogReadResponse struct {
|
||||
Log []*RequestLog `protobuf:"bytes,1,rep,name=log" json:"log,omitempty"`
|
||||
Offset *LogOffset `protobuf:"bytes,2,opt,name=offset" json:"offset,omitempty"`
|
||||
LastEndTime *int64 `protobuf:"varint,3,opt,name=last_end_time" json:"last_end_time,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *LogReadResponse) Reset() { *m = LogReadResponse{} }
|
||||
func (m *LogReadResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*LogReadResponse) ProtoMessage() {}
|
||||
|
||||
func (m *LogReadResponse) GetLog() []*RequestLog {
|
||||
if m != nil {
|
||||
return m.Log
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *LogReadResponse) GetOffset() *LogOffset {
|
||||
if m != nil {
|
||||
return m.Offset
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *LogReadResponse) GetLastEndTime() int64 {
|
||||
if m != nil && m.LastEndTime != nil {
|
||||
return *m.LastEndTime
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type LogUsageRecord struct {
|
||||
VersionId *string `protobuf:"bytes,1,opt,name=version_id" json:"version_id,omitempty"`
|
||||
StartTime *int32 `protobuf:"varint,2,opt,name=start_time" json:"start_time,omitempty"`
|
||||
EndTime *int32 `protobuf:"varint,3,opt,name=end_time" json:"end_time,omitempty"`
|
||||
Count *int64 `protobuf:"varint,4,opt,name=count" json:"count,omitempty"`
|
||||
TotalSize *int64 `protobuf:"varint,5,opt,name=total_size" json:"total_size,omitempty"`
|
||||
Records *int32 `protobuf:"varint,6,opt,name=records" json:"records,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *LogUsageRecord) Reset() { *m = LogUsageRecord{} }
|
||||
func (m *LogUsageRecord) String() string { return proto.CompactTextString(m) }
|
||||
func (*LogUsageRecord) ProtoMessage() {}
|
||||
|
||||
func (m *LogUsageRecord) GetVersionId() string {
|
||||
if m != nil && m.VersionId != nil {
|
||||
return *m.VersionId
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *LogUsageRecord) GetStartTime() int32 {
|
||||
if m != nil && m.StartTime != nil {
|
||||
return *m.StartTime
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogUsageRecord) GetEndTime() int32 {
|
||||
if m != nil && m.EndTime != nil {
|
||||
return *m.EndTime
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogUsageRecord) GetCount() int64 {
|
||||
if m != nil && m.Count != nil {
|
||||
return *m.Count
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogUsageRecord) GetTotalSize() int64 {
|
||||
if m != nil && m.TotalSize != nil {
|
||||
return *m.TotalSize
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogUsageRecord) GetRecords() int32 {
|
||||
if m != nil && m.Records != nil {
|
||||
return *m.Records
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type LogUsageRequest struct {
|
||||
AppId *string `protobuf:"bytes,1,req,name=app_id" json:"app_id,omitempty"`
|
||||
VersionId []string `protobuf:"bytes,2,rep,name=version_id" json:"version_id,omitempty"`
|
||||
StartTime *int32 `protobuf:"varint,3,opt,name=start_time" json:"start_time,omitempty"`
|
||||
EndTime *int32 `protobuf:"varint,4,opt,name=end_time" json:"end_time,omitempty"`
|
||||
ResolutionHours *uint32 `protobuf:"varint,5,opt,name=resolution_hours,def=1" json:"resolution_hours,omitempty"`
|
||||
CombineVersions *bool `protobuf:"varint,6,opt,name=combine_versions" json:"combine_versions,omitempty"`
|
||||
UsageVersion *int32 `protobuf:"varint,7,opt,name=usage_version" json:"usage_version,omitempty"`
|
||||
VersionsOnly *bool `protobuf:"varint,8,opt,name=versions_only" json:"versions_only,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *LogUsageRequest) Reset() { *m = LogUsageRequest{} }
|
||||
func (m *LogUsageRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*LogUsageRequest) ProtoMessage() {}
|
||||
|
||||
const Default_LogUsageRequest_ResolutionHours uint32 = 1
|
||||
|
||||
func (m *LogUsageRequest) GetAppId() string {
|
||||
if m != nil && m.AppId != nil {
|
||||
return *m.AppId
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *LogUsageRequest) GetVersionId() []string {
|
||||
if m != nil {
|
||||
return m.VersionId
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *LogUsageRequest) GetStartTime() int32 {
|
||||
if m != nil && m.StartTime != nil {
|
||||
return *m.StartTime
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogUsageRequest) GetEndTime() int32 {
|
||||
if m != nil && m.EndTime != nil {
|
||||
return *m.EndTime
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogUsageRequest) GetResolutionHours() uint32 {
|
||||
if m != nil && m.ResolutionHours != nil {
|
||||
return *m.ResolutionHours
|
||||
}
|
||||
return Default_LogUsageRequest_ResolutionHours
|
||||
}
|
||||
|
||||
func (m *LogUsageRequest) GetCombineVersions() bool {
|
||||
if m != nil && m.CombineVersions != nil {
|
||||
return *m.CombineVersions
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *LogUsageRequest) GetUsageVersion() int32 {
|
||||
if m != nil && m.UsageVersion != nil {
|
||||
return *m.UsageVersion
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *LogUsageRequest) GetVersionsOnly() bool {
|
||||
if m != nil && m.VersionsOnly != nil {
|
||||
return *m.VersionsOnly
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
type LogUsageResponse struct {
|
||||
Usage []*LogUsageRecord `protobuf:"bytes,1,rep,name=usage" json:"usage,omitempty"`
|
||||
Summary *LogUsageRecord `protobuf:"bytes,2,opt,name=summary" json:"summary,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *LogUsageResponse) Reset() { *m = LogUsageResponse{} }
|
||||
func (m *LogUsageResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*LogUsageResponse) ProtoMessage() {}
|
||||
|
||||
func (m *LogUsageResponse) GetUsage() []*LogUsageRecord {
|
||||
if m != nil {
|
||||
return m.Usage
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *LogUsageResponse) GetSummary() *LogUsageRecord {
|
||||
if m != nil {
|
||||
return m.Summary
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func init() {
|
||||
}
|
150
vendor/google.golang.org/appengine/internal/log/log_service.proto
generated
vendored
Normal file
150
vendor/google.golang.org/appengine/internal/log/log_service.proto
generated
vendored
Normal file
@@ -0,0 +1,150 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "log";
|
||||
|
||||
package appengine;
|
||||
|
||||
message LogServiceError {
|
||||
enum ErrorCode {
|
||||
OK = 0;
|
||||
INVALID_REQUEST = 1;
|
||||
STORAGE_ERROR = 2;
|
||||
}
|
||||
}
|
||||
|
||||
message UserAppLogLine {
|
||||
required int64 timestamp_usec = 1;
|
||||
required int64 level = 2;
|
||||
required string message = 3;
|
||||
}
|
||||
|
||||
message UserAppLogGroup {
|
||||
repeated UserAppLogLine log_line = 2;
|
||||
}
|
||||
|
||||
message FlushRequest {
|
||||
optional bytes logs = 1;
|
||||
}
|
||||
|
||||
message SetStatusRequest {
|
||||
required string status = 1;
|
||||
}
|
||||
|
||||
|
||||
message LogOffset {
|
||||
optional bytes request_id = 1;
|
||||
}
|
||||
|
||||
message LogLine {
|
||||
required int64 time = 1;
|
||||
required int32 level = 2;
|
||||
required string log_message = 3;
|
||||
}
|
||||
|
||||
message RequestLog {
|
||||
required string app_id = 1;
|
||||
optional string module_id = 37 [default="default"];
|
||||
required string version_id = 2;
|
||||
required bytes request_id = 3;
|
||||
optional LogOffset offset = 35;
|
||||
required string ip = 4;
|
||||
optional string nickname = 5;
|
||||
required int64 start_time = 6;
|
||||
required int64 end_time = 7;
|
||||
required int64 latency = 8;
|
||||
required int64 mcycles = 9;
|
||||
required string method = 10;
|
||||
required string resource = 11;
|
||||
required string http_version = 12;
|
||||
required int32 status = 13;
|
||||
required int64 response_size = 14;
|
||||
optional string referrer = 15;
|
||||
optional string user_agent = 16;
|
||||
required string url_map_entry = 17;
|
||||
required string combined = 18;
|
||||
optional int64 api_mcycles = 19;
|
||||
optional string host = 20;
|
||||
optional double cost = 21;
|
||||
|
||||
optional string task_queue_name = 22;
|
||||
optional string task_name = 23;
|
||||
|
||||
optional bool was_loading_request = 24;
|
||||
optional int64 pending_time = 25;
|
||||
optional int32 replica_index = 26 [default = -1];
|
||||
optional bool finished = 27 [default = true];
|
||||
optional bytes clone_key = 28;
|
||||
|
||||
repeated LogLine line = 29;
|
||||
|
||||
optional bool lines_incomplete = 36;
|
||||
optional bytes app_engine_release = 38;
|
||||
|
||||
optional int32 exit_reason = 30;
|
||||
optional bool was_throttled_for_time = 31;
|
||||
optional bool was_throttled_for_requests = 32;
|
||||
optional int64 throttled_time = 33;
|
||||
|
||||
optional bytes server_name = 34;
|
||||
}
|
||||
|
||||
message LogModuleVersion {
|
||||
optional string module_id = 1 [default="default"];
|
||||
optional string version_id = 2;
|
||||
}
|
||||
|
||||
message LogReadRequest {
|
||||
required string app_id = 1;
|
||||
repeated string version_id = 2;
|
||||
repeated LogModuleVersion module_version = 19;
|
||||
|
||||
optional int64 start_time = 3;
|
||||
optional int64 end_time = 4;
|
||||
optional LogOffset offset = 5;
|
||||
repeated bytes request_id = 6;
|
||||
|
||||
optional int32 minimum_log_level = 7;
|
||||
optional bool include_incomplete = 8;
|
||||
optional int64 count = 9;
|
||||
|
||||
optional string combined_log_regex = 14;
|
||||
optional string host_regex = 15;
|
||||
optional int32 replica_index = 16;
|
||||
|
||||
optional bool include_app_logs = 10;
|
||||
optional int32 app_logs_per_request = 17;
|
||||
optional bool include_host = 11;
|
||||
optional bool include_all = 12;
|
||||
optional bool cache_iterator = 13;
|
||||
optional int32 num_shards = 18;
|
||||
}
|
||||
|
||||
message LogReadResponse {
|
||||
repeated RequestLog log = 1;
|
||||
optional LogOffset offset = 2;
|
||||
optional int64 last_end_time = 3;
|
||||
}
|
||||
|
||||
message LogUsageRecord {
|
||||
optional string version_id = 1;
|
||||
optional int32 start_time = 2;
|
||||
optional int32 end_time = 3;
|
||||
optional int64 count = 4;
|
||||
optional int64 total_size = 5;
|
||||
optional int32 records = 6;
|
||||
}
|
||||
|
||||
message LogUsageRequest {
|
||||
required string app_id = 1;
|
||||
repeated string version_id = 2;
|
||||
optional int32 start_time = 3;
|
||||
optional int32 end_time = 4;
|
||||
optional uint32 resolution_hours = 5 [default = 1];
|
||||
optional bool combine_versions = 6;
|
||||
optional int32 usage_version = 7;
|
||||
optional bool versions_only = 8;
|
||||
}
|
||||
|
||||
message LogUsageResponse {
|
||||
repeated LogUsageRecord usage = 1;
|
||||
optional LogUsageRecord summary = 2;
|
||||
}
|
229
vendor/google.golang.org/appengine/internal/mail/mail_service.pb.go
generated
vendored
Normal file
229
vendor/google.golang.org/appengine/internal/mail/mail_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,229 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/mail/mail_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package mail is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/mail/mail_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
MailServiceError
|
||||
MailAttachment
|
||||
MailHeader
|
||||
MailMessage
|
||||
*/
|
||||
package mail
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type MailServiceError_ErrorCode int32
|
||||
|
||||
const (
|
||||
MailServiceError_OK MailServiceError_ErrorCode = 0
|
||||
MailServiceError_INTERNAL_ERROR MailServiceError_ErrorCode = 1
|
||||
MailServiceError_BAD_REQUEST MailServiceError_ErrorCode = 2
|
||||
MailServiceError_UNAUTHORIZED_SENDER MailServiceError_ErrorCode = 3
|
||||
MailServiceError_INVALID_ATTACHMENT_TYPE MailServiceError_ErrorCode = 4
|
||||
MailServiceError_INVALID_HEADER_NAME MailServiceError_ErrorCode = 5
|
||||
MailServiceError_INVALID_CONTENT_ID MailServiceError_ErrorCode = 6
|
||||
)
|
||||
|
||||
var MailServiceError_ErrorCode_name = map[int32]string{
|
||||
0: "OK",
|
||||
1: "INTERNAL_ERROR",
|
||||
2: "BAD_REQUEST",
|
||||
3: "UNAUTHORIZED_SENDER",
|
||||
4: "INVALID_ATTACHMENT_TYPE",
|
||||
5: "INVALID_HEADER_NAME",
|
||||
6: "INVALID_CONTENT_ID",
|
||||
}
|
||||
var MailServiceError_ErrorCode_value = map[string]int32{
|
||||
"OK": 0,
|
||||
"INTERNAL_ERROR": 1,
|
||||
"BAD_REQUEST": 2,
|
||||
"UNAUTHORIZED_SENDER": 3,
|
||||
"INVALID_ATTACHMENT_TYPE": 4,
|
||||
"INVALID_HEADER_NAME": 5,
|
||||
"INVALID_CONTENT_ID": 6,
|
||||
}
|
||||
|
||||
func (x MailServiceError_ErrorCode) Enum() *MailServiceError_ErrorCode {
|
||||
p := new(MailServiceError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x MailServiceError_ErrorCode) String() string {
|
||||
return proto.EnumName(MailServiceError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *MailServiceError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(MailServiceError_ErrorCode_value, data, "MailServiceError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = MailServiceError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type MailServiceError struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MailServiceError) Reset() { *m = MailServiceError{} }
|
||||
func (m *MailServiceError) String() string { return proto.CompactTextString(m) }
|
||||
func (*MailServiceError) ProtoMessage() {}
|
||||
|
||||
type MailAttachment struct {
|
||||
FileName *string `protobuf:"bytes,1,req,name=FileName" json:"FileName,omitempty"`
|
||||
Data []byte `protobuf:"bytes,2,req,name=Data" json:"Data,omitempty"`
|
||||
ContentID *string `protobuf:"bytes,3,opt,name=ContentID" json:"ContentID,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MailAttachment) Reset() { *m = MailAttachment{} }
|
||||
func (m *MailAttachment) String() string { return proto.CompactTextString(m) }
|
||||
func (*MailAttachment) ProtoMessage() {}
|
||||
|
||||
func (m *MailAttachment) GetFileName() string {
|
||||
if m != nil && m.FileName != nil {
|
||||
return *m.FileName
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MailAttachment) GetData() []byte {
|
||||
if m != nil {
|
||||
return m.Data
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MailAttachment) GetContentID() string {
|
||||
if m != nil && m.ContentID != nil {
|
||||
return *m.ContentID
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type MailHeader struct {
|
||||
Name *string `protobuf:"bytes,1,req,name=name" json:"name,omitempty"`
|
||||
Value *string `protobuf:"bytes,2,req,name=value" json:"value,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MailHeader) Reset() { *m = MailHeader{} }
|
||||
func (m *MailHeader) String() string { return proto.CompactTextString(m) }
|
||||
func (*MailHeader) ProtoMessage() {}
|
||||
|
||||
func (m *MailHeader) GetName() string {
|
||||
if m != nil && m.Name != nil {
|
||||
return *m.Name
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MailHeader) GetValue() string {
|
||||
if m != nil && m.Value != nil {
|
||||
return *m.Value
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type MailMessage struct {
|
||||
Sender *string `protobuf:"bytes,1,req,name=Sender" json:"Sender,omitempty"`
|
||||
ReplyTo *string `protobuf:"bytes,2,opt,name=ReplyTo" json:"ReplyTo,omitempty"`
|
||||
To []string `protobuf:"bytes,3,rep,name=To" json:"To,omitempty"`
|
||||
Cc []string `protobuf:"bytes,4,rep,name=Cc" json:"Cc,omitempty"`
|
||||
Bcc []string `protobuf:"bytes,5,rep,name=Bcc" json:"Bcc,omitempty"`
|
||||
Subject *string `protobuf:"bytes,6,req,name=Subject" json:"Subject,omitempty"`
|
||||
TextBody *string `protobuf:"bytes,7,opt,name=TextBody" json:"TextBody,omitempty"`
|
||||
HtmlBody *string `protobuf:"bytes,8,opt,name=HtmlBody" json:"HtmlBody,omitempty"`
|
||||
Attachment []*MailAttachment `protobuf:"bytes,9,rep,name=Attachment" json:"Attachment,omitempty"`
|
||||
Header []*MailHeader `protobuf:"bytes,10,rep,name=Header" json:"Header,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MailMessage) Reset() { *m = MailMessage{} }
|
||||
func (m *MailMessage) String() string { return proto.CompactTextString(m) }
|
||||
func (*MailMessage) ProtoMessage() {}
|
||||
|
||||
func (m *MailMessage) GetSender() string {
|
||||
if m != nil && m.Sender != nil {
|
||||
return *m.Sender
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MailMessage) GetReplyTo() string {
|
||||
if m != nil && m.ReplyTo != nil {
|
||||
return *m.ReplyTo
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MailMessage) GetTo() []string {
|
||||
if m != nil {
|
||||
return m.To
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MailMessage) GetCc() []string {
|
||||
if m != nil {
|
||||
return m.Cc
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MailMessage) GetBcc() []string {
|
||||
if m != nil {
|
||||
return m.Bcc
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MailMessage) GetSubject() string {
|
||||
if m != nil && m.Subject != nil {
|
||||
return *m.Subject
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MailMessage) GetTextBody() string {
|
||||
if m != nil && m.TextBody != nil {
|
||||
return *m.TextBody
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MailMessage) GetHtmlBody() string {
|
||||
if m != nil && m.HtmlBody != nil {
|
||||
return *m.HtmlBody
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MailMessage) GetAttachment() []*MailAttachment {
|
||||
if m != nil {
|
||||
return m.Attachment
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MailMessage) GetHeader() []*MailHeader {
|
||||
if m != nil {
|
||||
return m.Header
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func init() {
|
||||
}
|
45
vendor/google.golang.org/appengine/internal/mail/mail_service.proto
generated
vendored
Normal file
45
vendor/google.golang.org/appengine/internal/mail/mail_service.proto
generated
vendored
Normal file
@@ -0,0 +1,45 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "mail";
|
||||
|
||||
package appengine;
|
||||
|
||||
message MailServiceError {
|
||||
enum ErrorCode {
|
||||
OK = 0;
|
||||
INTERNAL_ERROR = 1;
|
||||
BAD_REQUEST = 2;
|
||||
UNAUTHORIZED_SENDER = 3;
|
||||
INVALID_ATTACHMENT_TYPE = 4;
|
||||
INVALID_HEADER_NAME = 5;
|
||||
INVALID_CONTENT_ID = 6;
|
||||
}
|
||||
}
|
||||
|
||||
message MailAttachment {
|
||||
required string FileName = 1;
|
||||
required bytes Data = 2;
|
||||
optional string ContentID = 3;
|
||||
}
|
||||
|
||||
message MailHeader {
|
||||
required string name = 1;
|
||||
required string value = 2;
|
||||
}
|
||||
|
||||
message MailMessage {
|
||||
required string Sender = 1;
|
||||
optional string ReplyTo = 2;
|
||||
|
||||
repeated string To = 3;
|
||||
repeated string Cc = 4;
|
||||
repeated string Bcc = 5;
|
||||
|
||||
required string Subject = 6;
|
||||
|
||||
optional string TextBody = 7;
|
||||
optional string HtmlBody = 8;
|
||||
|
||||
repeated MailAttachment Attachment = 9;
|
||||
|
||||
repeated MailHeader Header = 10;
|
||||
}
|
15
vendor/google.golang.org/appengine/internal/main.go
generated
vendored
Normal file
15
vendor/google.golang.org/appengine/internal/main.go
generated
vendored
Normal file
@@ -0,0 +1,15 @@
|
||||
// Copyright 2011 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
// +build appengine
|
||||
|
||||
package internal
|
||||
|
||||
import (
|
||||
"appengine_internal"
|
||||
)
|
||||
|
||||
func Main() {
|
||||
appengine_internal.Main()
|
||||
}
|
44
vendor/google.golang.org/appengine/internal/main_vm.go
generated
vendored
Normal file
44
vendor/google.golang.org/appengine/internal/main_vm.go
generated
vendored
Normal file
@@ -0,0 +1,44 @@
|
||||
// Copyright 2011 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
// +build !appengine
|
||||
|
||||
package internal
|
||||
|
||||
import (
|
||||
"io"
|
||||
"log"
|
||||
"net/http"
|
||||
"net/url"
|
||||
"os"
|
||||
)
|
||||
|
||||
func Main() {
|
||||
installHealthChecker(http.DefaultServeMux)
|
||||
|
||||
port := "8080"
|
||||
if s := os.Getenv("PORT"); s != "" {
|
||||
port = s
|
||||
}
|
||||
|
||||
if err := http.ListenAndServe(":"+port, http.HandlerFunc(handleHTTP)); err != nil {
|
||||
log.Fatalf("http.ListenAndServe: %v", err)
|
||||
}
|
||||
}
|
||||
|
||||
func installHealthChecker(mux *http.ServeMux) {
|
||||
// If no health check handler has been installed by this point, add a trivial one.
|
||||
const healthPath = "/_ah/health"
|
||||
hreq := &http.Request{
|
||||
Method: "GET",
|
||||
URL: &url.URL{
|
||||
Path: healthPath,
|
||||
},
|
||||
}
|
||||
if _, pat := mux.Handler(hreq); pat != healthPath {
|
||||
mux.HandleFunc(healthPath, func(w http.ResponseWriter, r *http.Request) {
|
||||
io.WriteString(w, "ok")
|
||||
})
|
||||
}
|
||||
}
|
938
vendor/google.golang.org/appengine/internal/memcache/memcache_service.pb.go
generated
vendored
Normal file
938
vendor/google.golang.org/appengine/internal/memcache/memcache_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,938 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/memcache/memcache_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package memcache is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/memcache/memcache_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
MemcacheServiceError
|
||||
AppOverride
|
||||
MemcacheGetRequest
|
||||
MemcacheGetResponse
|
||||
MemcacheSetRequest
|
||||
MemcacheSetResponse
|
||||
MemcacheDeleteRequest
|
||||
MemcacheDeleteResponse
|
||||
MemcacheIncrementRequest
|
||||
MemcacheIncrementResponse
|
||||
MemcacheBatchIncrementRequest
|
||||
MemcacheBatchIncrementResponse
|
||||
MemcacheFlushRequest
|
||||
MemcacheFlushResponse
|
||||
MemcacheStatsRequest
|
||||
MergedNamespaceStats
|
||||
MemcacheStatsResponse
|
||||
MemcacheGrabTailRequest
|
||||
MemcacheGrabTailResponse
|
||||
*/
|
||||
package memcache
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type MemcacheServiceError_ErrorCode int32
|
||||
|
||||
const (
|
||||
MemcacheServiceError_OK MemcacheServiceError_ErrorCode = 0
|
||||
MemcacheServiceError_UNSPECIFIED_ERROR MemcacheServiceError_ErrorCode = 1
|
||||
MemcacheServiceError_NAMESPACE_NOT_SET MemcacheServiceError_ErrorCode = 2
|
||||
MemcacheServiceError_PERMISSION_DENIED MemcacheServiceError_ErrorCode = 3
|
||||
MemcacheServiceError_INVALID_VALUE MemcacheServiceError_ErrorCode = 6
|
||||
)
|
||||
|
||||
var MemcacheServiceError_ErrorCode_name = map[int32]string{
|
||||
0: "OK",
|
||||
1: "UNSPECIFIED_ERROR",
|
||||
2: "NAMESPACE_NOT_SET",
|
||||
3: "PERMISSION_DENIED",
|
||||
6: "INVALID_VALUE",
|
||||
}
|
||||
var MemcacheServiceError_ErrorCode_value = map[string]int32{
|
||||
"OK": 0,
|
||||
"UNSPECIFIED_ERROR": 1,
|
||||
"NAMESPACE_NOT_SET": 2,
|
||||
"PERMISSION_DENIED": 3,
|
||||
"INVALID_VALUE": 6,
|
||||
}
|
||||
|
||||
func (x MemcacheServiceError_ErrorCode) Enum() *MemcacheServiceError_ErrorCode {
|
||||
p := new(MemcacheServiceError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x MemcacheServiceError_ErrorCode) String() string {
|
||||
return proto.EnumName(MemcacheServiceError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *MemcacheServiceError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(MemcacheServiceError_ErrorCode_value, data, "MemcacheServiceError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = MemcacheServiceError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheSetRequest_SetPolicy int32
|
||||
|
||||
const (
|
||||
MemcacheSetRequest_SET MemcacheSetRequest_SetPolicy = 1
|
||||
MemcacheSetRequest_ADD MemcacheSetRequest_SetPolicy = 2
|
||||
MemcacheSetRequest_REPLACE MemcacheSetRequest_SetPolicy = 3
|
||||
MemcacheSetRequest_CAS MemcacheSetRequest_SetPolicy = 4
|
||||
)
|
||||
|
||||
var MemcacheSetRequest_SetPolicy_name = map[int32]string{
|
||||
1: "SET",
|
||||
2: "ADD",
|
||||
3: "REPLACE",
|
||||
4: "CAS",
|
||||
}
|
||||
var MemcacheSetRequest_SetPolicy_value = map[string]int32{
|
||||
"SET": 1,
|
||||
"ADD": 2,
|
||||
"REPLACE": 3,
|
||||
"CAS": 4,
|
||||
}
|
||||
|
||||
func (x MemcacheSetRequest_SetPolicy) Enum() *MemcacheSetRequest_SetPolicy {
|
||||
p := new(MemcacheSetRequest_SetPolicy)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x MemcacheSetRequest_SetPolicy) String() string {
|
||||
return proto.EnumName(MemcacheSetRequest_SetPolicy_name, int32(x))
|
||||
}
|
||||
func (x *MemcacheSetRequest_SetPolicy) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(MemcacheSetRequest_SetPolicy_value, data, "MemcacheSetRequest_SetPolicy")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = MemcacheSetRequest_SetPolicy(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheSetResponse_SetStatusCode int32
|
||||
|
||||
const (
|
||||
MemcacheSetResponse_STORED MemcacheSetResponse_SetStatusCode = 1
|
||||
MemcacheSetResponse_NOT_STORED MemcacheSetResponse_SetStatusCode = 2
|
||||
MemcacheSetResponse_ERROR MemcacheSetResponse_SetStatusCode = 3
|
||||
MemcacheSetResponse_EXISTS MemcacheSetResponse_SetStatusCode = 4
|
||||
)
|
||||
|
||||
var MemcacheSetResponse_SetStatusCode_name = map[int32]string{
|
||||
1: "STORED",
|
||||
2: "NOT_STORED",
|
||||
3: "ERROR",
|
||||
4: "EXISTS",
|
||||
}
|
||||
var MemcacheSetResponse_SetStatusCode_value = map[string]int32{
|
||||
"STORED": 1,
|
||||
"NOT_STORED": 2,
|
||||
"ERROR": 3,
|
||||
"EXISTS": 4,
|
||||
}
|
||||
|
||||
func (x MemcacheSetResponse_SetStatusCode) Enum() *MemcacheSetResponse_SetStatusCode {
|
||||
p := new(MemcacheSetResponse_SetStatusCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x MemcacheSetResponse_SetStatusCode) String() string {
|
||||
return proto.EnumName(MemcacheSetResponse_SetStatusCode_name, int32(x))
|
||||
}
|
||||
func (x *MemcacheSetResponse_SetStatusCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(MemcacheSetResponse_SetStatusCode_value, data, "MemcacheSetResponse_SetStatusCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = MemcacheSetResponse_SetStatusCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheDeleteResponse_DeleteStatusCode int32
|
||||
|
||||
const (
|
||||
MemcacheDeleteResponse_DELETED MemcacheDeleteResponse_DeleteStatusCode = 1
|
||||
MemcacheDeleteResponse_NOT_FOUND MemcacheDeleteResponse_DeleteStatusCode = 2
|
||||
)
|
||||
|
||||
var MemcacheDeleteResponse_DeleteStatusCode_name = map[int32]string{
|
||||
1: "DELETED",
|
||||
2: "NOT_FOUND",
|
||||
}
|
||||
var MemcacheDeleteResponse_DeleteStatusCode_value = map[string]int32{
|
||||
"DELETED": 1,
|
||||
"NOT_FOUND": 2,
|
||||
}
|
||||
|
||||
func (x MemcacheDeleteResponse_DeleteStatusCode) Enum() *MemcacheDeleteResponse_DeleteStatusCode {
|
||||
p := new(MemcacheDeleteResponse_DeleteStatusCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x MemcacheDeleteResponse_DeleteStatusCode) String() string {
|
||||
return proto.EnumName(MemcacheDeleteResponse_DeleteStatusCode_name, int32(x))
|
||||
}
|
||||
func (x *MemcacheDeleteResponse_DeleteStatusCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(MemcacheDeleteResponse_DeleteStatusCode_value, data, "MemcacheDeleteResponse_DeleteStatusCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = MemcacheDeleteResponse_DeleteStatusCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheIncrementRequest_Direction int32
|
||||
|
||||
const (
|
||||
MemcacheIncrementRequest_INCREMENT MemcacheIncrementRequest_Direction = 1
|
||||
MemcacheIncrementRequest_DECREMENT MemcacheIncrementRequest_Direction = 2
|
||||
)
|
||||
|
||||
var MemcacheIncrementRequest_Direction_name = map[int32]string{
|
||||
1: "INCREMENT",
|
||||
2: "DECREMENT",
|
||||
}
|
||||
var MemcacheIncrementRequest_Direction_value = map[string]int32{
|
||||
"INCREMENT": 1,
|
||||
"DECREMENT": 2,
|
||||
}
|
||||
|
||||
func (x MemcacheIncrementRequest_Direction) Enum() *MemcacheIncrementRequest_Direction {
|
||||
p := new(MemcacheIncrementRequest_Direction)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x MemcacheIncrementRequest_Direction) String() string {
|
||||
return proto.EnumName(MemcacheIncrementRequest_Direction_name, int32(x))
|
||||
}
|
||||
func (x *MemcacheIncrementRequest_Direction) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(MemcacheIncrementRequest_Direction_value, data, "MemcacheIncrementRequest_Direction")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = MemcacheIncrementRequest_Direction(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheIncrementResponse_IncrementStatusCode int32
|
||||
|
||||
const (
|
||||
MemcacheIncrementResponse_OK MemcacheIncrementResponse_IncrementStatusCode = 1
|
||||
MemcacheIncrementResponse_NOT_CHANGED MemcacheIncrementResponse_IncrementStatusCode = 2
|
||||
MemcacheIncrementResponse_ERROR MemcacheIncrementResponse_IncrementStatusCode = 3
|
||||
)
|
||||
|
||||
var MemcacheIncrementResponse_IncrementStatusCode_name = map[int32]string{
|
||||
1: "OK",
|
||||
2: "NOT_CHANGED",
|
||||
3: "ERROR",
|
||||
}
|
||||
var MemcacheIncrementResponse_IncrementStatusCode_value = map[string]int32{
|
||||
"OK": 1,
|
||||
"NOT_CHANGED": 2,
|
||||
"ERROR": 3,
|
||||
}
|
||||
|
||||
func (x MemcacheIncrementResponse_IncrementStatusCode) Enum() *MemcacheIncrementResponse_IncrementStatusCode {
|
||||
p := new(MemcacheIncrementResponse_IncrementStatusCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x MemcacheIncrementResponse_IncrementStatusCode) String() string {
|
||||
return proto.EnumName(MemcacheIncrementResponse_IncrementStatusCode_name, int32(x))
|
||||
}
|
||||
func (x *MemcacheIncrementResponse_IncrementStatusCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(MemcacheIncrementResponse_IncrementStatusCode_value, data, "MemcacheIncrementResponse_IncrementStatusCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = MemcacheIncrementResponse_IncrementStatusCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheServiceError struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheServiceError) Reset() { *m = MemcacheServiceError{} }
|
||||
func (m *MemcacheServiceError) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheServiceError) ProtoMessage() {}
|
||||
|
||||
type AppOverride struct {
|
||||
AppId *string `protobuf:"bytes,1,req,name=app_id" json:"app_id,omitempty"`
|
||||
NumMemcachegBackends *int32 `protobuf:"varint,2,opt,name=num_memcacheg_backends" json:"num_memcacheg_backends,omitempty"`
|
||||
IgnoreShardlock *bool `protobuf:"varint,3,opt,name=ignore_shardlock" json:"ignore_shardlock,omitempty"`
|
||||
MemcachePoolHint *string `protobuf:"bytes,4,opt,name=memcache_pool_hint" json:"memcache_pool_hint,omitempty"`
|
||||
MemcacheShardingStrategy []byte `protobuf:"bytes,5,opt,name=memcache_sharding_strategy" json:"memcache_sharding_strategy,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *AppOverride) Reset() { *m = AppOverride{} }
|
||||
func (m *AppOverride) String() string { return proto.CompactTextString(m) }
|
||||
func (*AppOverride) ProtoMessage() {}
|
||||
|
||||
func (m *AppOverride) GetAppId() string {
|
||||
if m != nil && m.AppId != nil {
|
||||
return *m.AppId
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *AppOverride) GetNumMemcachegBackends() int32 {
|
||||
if m != nil && m.NumMemcachegBackends != nil {
|
||||
return *m.NumMemcachegBackends
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *AppOverride) GetIgnoreShardlock() bool {
|
||||
if m != nil && m.IgnoreShardlock != nil {
|
||||
return *m.IgnoreShardlock
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *AppOverride) GetMemcachePoolHint() string {
|
||||
if m != nil && m.MemcachePoolHint != nil {
|
||||
return *m.MemcachePoolHint
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *AppOverride) GetMemcacheShardingStrategy() []byte {
|
||||
if m != nil {
|
||||
return m.MemcacheShardingStrategy
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheGetRequest struct {
|
||||
Key [][]byte `protobuf:"bytes,1,rep,name=key" json:"key,omitempty"`
|
||||
NameSpace *string `protobuf:"bytes,2,opt,name=name_space,def=" json:"name_space,omitempty"`
|
||||
ForCas *bool `protobuf:"varint,4,opt,name=for_cas" json:"for_cas,omitempty"`
|
||||
Override *AppOverride `protobuf:"bytes,5,opt,name=override" json:"override,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheGetRequest) Reset() { *m = MemcacheGetRequest{} }
|
||||
func (m *MemcacheGetRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheGetRequest) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheGetRequest) GetKey() [][]byte {
|
||||
if m != nil {
|
||||
return m.Key
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MemcacheGetRequest) GetNameSpace() string {
|
||||
if m != nil && m.NameSpace != nil {
|
||||
return *m.NameSpace
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MemcacheGetRequest) GetForCas() bool {
|
||||
if m != nil && m.ForCas != nil {
|
||||
return *m.ForCas
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *MemcacheGetRequest) GetOverride() *AppOverride {
|
||||
if m != nil {
|
||||
return m.Override
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheGetResponse struct {
|
||||
Item []*MemcacheGetResponse_Item `protobuf:"group,1,rep,name=Item" json:"item,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheGetResponse) Reset() { *m = MemcacheGetResponse{} }
|
||||
func (m *MemcacheGetResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheGetResponse) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheGetResponse) GetItem() []*MemcacheGetResponse_Item {
|
||||
if m != nil {
|
||||
return m.Item
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheGetResponse_Item struct {
|
||||
Key []byte `protobuf:"bytes,2,req,name=key" json:"key,omitempty"`
|
||||
Value []byte `protobuf:"bytes,3,req,name=value" json:"value,omitempty"`
|
||||
Flags *uint32 `protobuf:"fixed32,4,opt,name=flags" json:"flags,omitempty"`
|
||||
CasId *uint64 `protobuf:"fixed64,5,opt,name=cas_id" json:"cas_id,omitempty"`
|
||||
ExpiresInSeconds *int32 `protobuf:"varint,6,opt,name=expires_in_seconds" json:"expires_in_seconds,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheGetResponse_Item) Reset() { *m = MemcacheGetResponse_Item{} }
|
||||
func (m *MemcacheGetResponse_Item) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheGetResponse_Item) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheGetResponse_Item) GetKey() []byte {
|
||||
if m != nil {
|
||||
return m.Key
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MemcacheGetResponse_Item) GetValue() []byte {
|
||||
if m != nil {
|
||||
return m.Value
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MemcacheGetResponse_Item) GetFlags() uint32 {
|
||||
if m != nil && m.Flags != nil {
|
||||
return *m.Flags
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MemcacheGetResponse_Item) GetCasId() uint64 {
|
||||
if m != nil && m.CasId != nil {
|
||||
return *m.CasId
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MemcacheGetResponse_Item) GetExpiresInSeconds() int32 {
|
||||
if m != nil && m.ExpiresInSeconds != nil {
|
||||
return *m.ExpiresInSeconds
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type MemcacheSetRequest struct {
|
||||
Item []*MemcacheSetRequest_Item `protobuf:"group,1,rep,name=Item" json:"item,omitempty"`
|
||||
NameSpace *string `protobuf:"bytes,7,opt,name=name_space,def=" json:"name_space,omitempty"`
|
||||
Override *AppOverride `protobuf:"bytes,10,opt,name=override" json:"override,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheSetRequest) Reset() { *m = MemcacheSetRequest{} }
|
||||
func (m *MemcacheSetRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheSetRequest) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheSetRequest) GetItem() []*MemcacheSetRequest_Item {
|
||||
if m != nil {
|
||||
return m.Item
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MemcacheSetRequest) GetNameSpace() string {
|
||||
if m != nil && m.NameSpace != nil {
|
||||
return *m.NameSpace
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MemcacheSetRequest) GetOverride() *AppOverride {
|
||||
if m != nil {
|
||||
return m.Override
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheSetRequest_Item struct {
|
||||
Key []byte `protobuf:"bytes,2,req,name=key" json:"key,omitempty"`
|
||||
Value []byte `protobuf:"bytes,3,req,name=value" json:"value,omitempty"`
|
||||
Flags *uint32 `protobuf:"fixed32,4,opt,name=flags" json:"flags,omitempty"`
|
||||
SetPolicy *MemcacheSetRequest_SetPolicy `protobuf:"varint,5,opt,name=set_policy,enum=appengine.MemcacheSetRequest_SetPolicy,def=1" json:"set_policy,omitempty"`
|
||||
ExpirationTime *uint32 `protobuf:"fixed32,6,opt,name=expiration_time,def=0" json:"expiration_time,omitempty"`
|
||||
CasId *uint64 `protobuf:"fixed64,8,opt,name=cas_id" json:"cas_id,omitempty"`
|
||||
ForCas *bool `protobuf:"varint,9,opt,name=for_cas" json:"for_cas,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheSetRequest_Item) Reset() { *m = MemcacheSetRequest_Item{} }
|
||||
func (m *MemcacheSetRequest_Item) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheSetRequest_Item) ProtoMessage() {}
|
||||
|
||||
const Default_MemcacheSetRequest_Item_SetPolicy MemcacheSetRequest_SetPolicy = MemcacheSetRequest_SET
|
||||
const Default_MemcacheSetRequest_Item_ExpirationTime uint32 = 0
|
||||
|
||||
func (m *MemcacheSetRequest_Item) GetKey() []byte {
|
||||
if m != nil {
|
||||
return m.Key
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MemcacheSetRequest_Item) GetValue() []byte {
|
||||
if m != nil {
|
||||
return m.Value
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MemcacheSetRequest_Item) GetFlags() uint32 {
|
||||
if m != nil && m.Flags != nil {
|
||||
return *m.Flags
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MemcacheSetRequest_Item) GetSetPolicy() MemcacheSetRequest_SetPolicy {
|
||||
if m != nil && m.SetPolicy != nil {
|
||||
return *m.SetPolicy
|
||||
}
|
||||
return Default_MemcacheSetRequest_Item_SetPolicy
|
||||
}
|
||||
|
||||
func (m *MemcacheSetRequest_Item) GetExpirationTime() uint32 {
|
||||
if m != nil && m.ExpirationTime != nil {
|
||||
return *m.ExpirationTime
|
||||
}
|
||||
return Default_MemcacheSetRequest_Item_ExpirationTime
|
||||
}
|
||||
|
||||
func (m *MemcacheSetRequest_Item) GetCasId() uint64 {
|
||||
if m != nil && m.CasId != nil {
|
||||
return *m.CasId
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MemcacheSetRequest_Item) GetForCas() bool {
|
||||
if m != nil && m.ForCas != nil {
|
||||
return *m.ForCas
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
type MemcacheSetResponse struct {
|
||||
SetStatus []MemcacheSetResponse_SetStatusCode `protobuf:"varint,1,rep,name=set_status,enum=appengine.MemcacheSetResponse_SetStatusCode" json:"set_status,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheSetResponse) Reset() { *m = MemcacheSetResponse{} }
|
||||
func (m *MemcacheSetResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheSetResponse) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheSetResponse) GetSetStatus() []MemcacheSetResponse_SetStatusCode {
|
||||
if m != nil {
|
||||
return m.SetStatus
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheDeleteRequest struct {
|
||||
Item []*MemcacheDeleteRequest_Item `protobuf:"group,1,rep,name=Item" json:"item,omitempty"`
|
||||
NameSpace *string `protobuf:"bytes,4,opt,name=name_space,def=" json:"name_space,omitempty"`
|
||||
Override *AppOverride `protobuf:"bytes,5,opt,name=override" json:"override,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheDeleteRequest) Reset() { *m = MemcacheDeleteRequest{} }
|
||||
func (m *MemcacheDeleteRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheDeleteRequest) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheDeleteRequest) GetItem() []*MemcacheDeleteRequest_Item {
|
||||
if m != nil {
|
||||
return m.Item
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MemcacheDeleteRequest) GetNameSpace() string {
|
||||
if m != nil && m.NameSpace != nil {
|
||||
return *m.NameSpace
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MemcacheDeleteRequest) GetOverride() *AppOverride {
|
||||
if m != nil {
|
||||
return m.Override
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheDeleteRequest_Item struct {
|
||||
Key []byte `protobuf:"bytes,2,req,name=key" json:"key,omitempty"`
|
||||
DeleteTime *uint32 `protobuf:"fixed32,3,opt,name=delete_time,def=0" json:"delete_time,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheDeleteRequest_Item) Reset() { *m = MemcacheDeleteRequest_Item{} }
|
||||
func (m *MemcacheDeleteRequest_Item) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheDeleteRequest_Item) ProtoMessage() {}
|
||||
|
||||
const Default_MemcacheDeleteRequest_Item_DeleteTime uint32 = 0
|
||||
|
||||
func (m *MemcacheDeleteRequest_Item) GetKey() []byte {
|
||||
if m != nil {
|
||||
return m.Key
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MemcacheDeleteRequest_Item) GetDeleteTime() uint32 {
|
||||
if m != nil && m.DeleteTime != nil {
|
||||
return *m.DeleteTime
|
||||
}
|
||||
return Default_MemcacheDeleteRequest_Item_DeleteTime
|
||||
}
|
||||
|
||||
type MemcacheDeleteResponse struct {
|
||||
DeleteStatus []MemcacheDeleteResponse_DeleteStatusCode `protobuf:"varint,1,rep,name=delete_status,enum=appengine.MemcacheDeleteResponse_DeleteStatusCode" json:"delete_status,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheDeleteResponse) Reset() { *m = MemcacheDeleteResponse{} }
|
||||
func (m *MemcacheDeleteResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheDeleteResponse) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheDeleteResponse) GetDeleteStatus() []MemcacheDeleteResponse_DeleteStatusCode {
|
||||
if m != nil {
|
||||
return m.DeleteStatus
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheIncrementRequest struct {
|
||||
Key []byte `protobuf:"bytes,1,req,name=key" json:"key,omitempty"`
|
||||
NameSpace *string `protobuf:"bytes,4,opt,name=name_space,def=" json:"name_space,omitempty"`
|
||||
Delta *uint64 `protobuf:"varint,2,opt,name=delta,def=1" json:"delta,omitempty"`
|
||||
Direction *MemcacheIncrementRequest_Direction `protobuf:"varint,3,opt,name=direction,enum=appengine.MemcacheIncrementRequest_Direction,def=1" json:"direction,omitempty"`
|
||||
InitialValue *uint64 `protobuf:"varint,5,opt,name=initial_value" json:"initial_value,omitempty"`
|
||||
InitialFlags *uint32 `protobuf:"fixed32,6,opt,name=initial_flags" json:"initial_flags,omitempty"`
|
||||
Override *AppOverride `protobuf:"bytes,7,opt,name=override" json:"override,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheIncrementRequest) Reset() { *m = MemcacheIncrementRequest{} }
|
||||
func (m *MemcacheIncrementRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheIncrementRequest) ProtoMessage() {}
|
||||
|
||||
const Default_MemcacheIncrementRequest_Delta uint64 = 1
|
||||
const Default_MemcacheIncrementRequest_Direction MemcacheIncrementRequest_Direction = MemcacheIncrementRequest_INCREMENT
|
||||
|
||||
func (m *MemcacheIncrementRequest) GetKey() []byte {
|
||||
if m != nil {
|
||||
return m.Key
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MemcacheIncrementRequest) GetNameSpace() string {
|
||||
if m != nil && m.NameSpace != nil {
|
||||
return *m.NameSpace
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MemcacheIncrementRequest) GetDelta() uint64 {
|
||||
if m != nil && m.Delta != nil {
|
||||
return *m.Delta
|
||||
}
|
||||
return Default_MemcacheIncrementRequest_Delta
|
||||
}
|
||||
|
||||
func (m *MemcacheIncrementRequest) GetDirection() MemcacheIncrementRequest_Direction {
|
||||
if m != nil && m.Direction != nil {
|
||||
return *m.Direction
|
||||
}
|
||||
return Default_MemcacheIncrementRequest_Direction
|
||||
}
|
||||
|
||||
func (m *MemcacheIncrementRequest) GetInitialValue() uint64 {
|
||||
if m != nil && m.InitialValue != nil {
|
||||
return *m.InitialValue
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MemcacheIncrementRequest) GetInitialFlags() uint32 {
|
||||
if m != nil && m.InitialFlags != nil {
|
||||
return *m.InitialFlags
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MemcacheIncrementRequest) GetOverride() *AppOverride {
|
||||
if m != nil {
|
||||
return m.Override
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheIncrementResponse struct {
|
||||
NewValue *uint64 `protobuf:"varint,1,opt,name=new_value" json:"new_value,omitempty"`
|
||||
IncrementStatus *MemcacheIncrementResponse_IncrementStatusCode `protobuf:"varint,2,opt,name=increment_status,enum=appengine.MemcacheIncrementResponse_IncrementStatusCode" json:"increment_status,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheIncrementResponse) Reset() { *m = MemcacheIncrementResponse{} }
|
||||
func (m *MemcacheIncrementResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheIncrementResponse) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheIncrementResponse) GetNewValue() uint64 {
|
||||
if m != nil && m.NewValue != nil {
|
||||
return *m.NewValue
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MemcacheIncrementResponse) GetIncrementStatus() MemcacheIncrementResponse_IncrementStatusCode {
|
||||
if m != nil && m.IncrementStatus != nil {
|
||||
return *m.IncrementStatus
|
||||
}
|
||||
return MemcacheIncrementResponse_OK
|
||||
}
|
||||
|
||||
type MemcacheBatchIncrementRequest struct {
|
||||
NameSpace *string `protobuf:"bytes,1,opt,name=name_space,def=" json:"name_space,omitempty"`
|
||||
Item []*MemcacheIncrementRequest `protobuf:"bytes,2,rep,name=item" json:"item,omitempty"`
|
||||
Override *AppOverride `protobuf:"bytes,3,opt,name=override" json:"override,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheBatchIncrementRequest) Reset() { *m = MemcacheBatchIncrementRequest{} }
|
||||
func (m *MemcacheBatchIncrementRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheBatchIncrementRequest) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheBatchIncrementRequest) GetNameSpace() string {
|
||||
if m != nil && m.NameSpace != nil {
|
||||
return *m.NameSpace
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MemcacheBatchIncrementRequest) GetItem() []*MemcacheIncrementRequest {
|
||||
if m != nil {
|
||||
return m.Item
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MemcacheBatchIncrementRequest) GetOverride() *AppOverride {
|
||||
if m != nil {
|
||||
return m.Override
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheBatchIncrementResponse struct {
|
||||
Item []*MemcacheIncrementResponse `protobuf:"bytes,1,rep,name=item" json:"item,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheBatchIncrementResponse) Reset() { *m = MemcacheBatchIncrementResponse{} }
|
||||
func (m *MemcacheBatchIncrementResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheBatchIncrementResponse) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheBatchIncrementResponse) GetItem() []*MemcacheIncrementResponse {
|
||||
if m != nil {
|
||||
return m.Item
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheFlushRequest struct {
|
||||
Override *AppOverride `protobuf:"bytes,1,opt,name=override" json:"override,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheFlushRequest) Reset() { *m = MemcacheFlushRequest{} }
|
||||
func (m *MemcacheFlushRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheFlushRequest) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheFlushRequest) GetOverride() *AppOverride {
|
||||
if m != nil {
|
||||
return m.Override
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheFlushResponse struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheFlushResponse) Reset() { *m = MemcacheFlushResponse{} }
|
||||
func (m *MemcacheFlushResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheFlushResponse) ProtoMessage() {}
|
||||
|
||||
type MemcacheStatsRequest struct {
|
||||
Override *AppOverride `protobuf:"bytes,1,opt,name=override" json:"override,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheStatsRequest) Reset() { *m = MemcacheStatsRequest{} }
|
||||
func (m *MemcacheStatsRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheStatsRequest) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheStatsRequest) GetOverride() *AppOverride {
|
||||
if m != nil {
|
||||
return m.Override
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MergedNamespaceStats struct {
|
||||
Hits *uint64 `protobuf:"varint,1,req,name=hits" json:"hits,omitempty"`
|
||||
Misses *uint64 `protobuf:"varint,2,req,name=misses" json:"misses,omitempty"`
|
||||
ByteHits *uint64 `protobuf:"varint,3,req,name=byte_hits" json:"byte_hits,omitempty"`
|
||||
Items *uint64 `protobuf:"varint,4,req,name=items" json:"items,omitempty"`
|
||||
Bytes *uint64 `protobuf:"varint,5,req,name=bytes" json:"bytes,omitempty"`
|
||||
OldestItemAge *uint32 `protobuf:"fixed32,6,req,name=oldest_item_age" json:"oldest_item_age,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MergedNamespaceStats) Reset() { *m = MergedNamespaceStats{} }
|
||||
func (m *MergedNamespaceStats) String() string { return proto.CompactTextString(m) }
|
||||
func (*MergedNamespaceStats) ProtoMessage() {}
|
||||
|
||||
func (m *MergedNamespaceStats) GetHits() uint64 {
|
||||
if m != nil && m.Hits != nil {
|
||||
return *m.Hits
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MergedNamespaceStats) GetMisses() uint64 {
|
||||
if m != nil && m.Misses != nil {
|
||||
return *m.Misses
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MergedNamespaceStats) GetByteHits() uint64 {
|
||||
if m != nil && m.ByteHits != nil {
|
||||
return *m.ByteHits
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MergedNamespaceStats) GetItems() uint64 {
|
||||
if m != nil && m.Items != nil {
|
||||
return *m.Items
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MergedNamespaceStats) GetBytes() uint64 {
|
||||
if m != nil && m.Bytes != nil {
|
||||
return *m.Bytes
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MergedNamespaceStats) GetOldestItemAge() uint32 {
|
||||
if m != nil && m.OldestItemAge != nil {
|
||||
return *m.OldestItemAge
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type MemcacheStatsResponse struct {
|
||||
Stats *MergedNamespaceStats `protobuf:"bytes,1,opt,name=stats" json:"stats,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheStatsResponse) Reset() { *m = MemcacheStatsResponse{} }
|
||||
func (m *MemcacheStatsResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheStatsResponse) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheStatsResponse) GetStats() *MergedNamespaceStats {
|
||||
if m != nil {
|
||||
return m.Stats
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheGrabTailRequest struct {
|
||||
ItemCount *int32 `protobuf:"varint,1,req,name=item_count" json:"item_count,omitempty"`
|
||||
NameSpace *string `protobuf:"bytes,2,opt,name=name_space,def=" json:"name_space,omitempty"`
|
||||
Override *AppOverride `protobuf:"bytes,3,opt,name=override" json:"override,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheGrabTailRequest) Reset() { *m = MemcacheGrabTailRequest{} }
|
||||
func (m *MemcacheGrabTailRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheGrabTailRequest) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheGrabTailRequest) GetItemCount() int32 {
|
||||
if m != nil && m.ItemCount != nil {
|
||||
return *m.ItemCount
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *MemcacheGrabTailRequest) GetNameSpace() string {
|
||||
if m != nil && m.NameSpace != nil {
|
||||
return *m.NameSpace
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *MemcacheGrabTailRequest) GetOverride() *AppOverride {
|
||||
if m != nil {
|
||||
return m.Override
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheGrabTailResponse struct {
|
||||
Item []*MemcacheGrabTailResponse_Item `protobuf:"group,1,rep,name=Item" json:"item,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheGrabTailResponse) Reset() { *m = MemcacheGrabTailResponse{} }
|
||||
func (m *MemcacheGrabTailResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheGrabTailResponse) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheGrabTailResponse) GetItem() []*MemcacheGrabTailResponse_Item {
|
||||
if m != nil {
|
||||
return m.Item
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type MemcacheGrabTailResponse_Item struct {
|
||||
Value []byte `protobuf:"bytes,2,req,name=value" json:"value,omitempty"`
|
||||
Flags *uint32 `protobuf:"fixed32,3,opt,name=flags" json:"flags,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *MemcacheGrabTailResponse_Item) Reset() { *m = MemcacheGrabTailResponse_Item{} }
|
||||
func (m *MemcacheGrabTailResponse_Item) String() string { return proto.CompactTextString(m) }
|
||||
func (*MemcacheGrabTailResponse_Item) ProtoMessage() {}
|
||||
|
||||
func (m *MemcacheGrabTailResponse_Item) GetValue() []byte {
|
||||
if m != nil {
|
||||
return m.Value
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *MemcacheGrabTailResponse_Item) GetFlags() uint32 {
|
||||
if m != nil && m.Flags != nil {
|
||||
return *m.Flags
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func init() {
|
||||
}
|
165
vendor/google.golang.org/appengine/internal/memcache/memcache_service.proto
generated
vendored
Normal file
165
vendor/google.golang.org/appengine/internal/memcache/memcache_service.proto
generated
vendored
Normal file
@@ -0,0 +1,165 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "memcache";
|
||||
|
||||
package appengine;
|
||||
|
||||
message MemcacheServiceError {
|
||||
enum ErrorCode {
|
||||
OK = 0;
|
||||
UNSPECIFIED_ERROR = 1;
|
||||
NAMESPACE_NOT_SET = 2;
|
||||
PERMISSION_DENIED = 3;
|
||||
INVALID_VALUE = 6;
|
||||
}
|
||||
}
|
||||
|
||||
message AppOverride {
|
||||
required string app_id = 1;
|
||||
|
||||
optional int32 num_memcacheg_backends = 2 [deprecated=true];
|
||||
optional bool ignore_shardlock = 3 [deprecated=true];
|
||||
optional string memcache_pool_hint = 4 [deprecated=true];
|
||||
optional bytes memcache_sharding_strategy = 5 [deprecated=true];
|
||||
}
|
||||
|
||||
message MemcacheGetRequest {
|
||||
repeated bytes key = 1;
|
||||
optional string name_space = 2 [default = ""];
|
||||
optional bool for_cas = 4;
|
||||
optional AppOverride override = 5;
|
||||
}
|
||||
|
||||
message MemcacheGetResponse {
|
||||
repeated group Item = 1 {
|
||||
required bytes key = 2;
|
||||
required bytes value = 3;
|
||||
optional fixed32 flags = 4;
|
||||
optional fixed64 cas_id = 5;
|
||||
optional int32 expires_in_seconds = 6;
|
||||
}
|
||||
}
|
||||
|
||||
message MemcacheSetRequest {
|
||||
enum SetPolicy {
|
||||
SET = 1;
|
||||
ADD = 2;
|
||||
REPLACE = 3;
|
||||
CAS = 4;
|
||||
}
|
||||
repeated group Item = 1 {
|
||||
required bytes key = 2;
|
||||
required bytes value = 3;
|
||||
|
||||
optional fixed32 flags = 4;
|
||||
optional SetPolicy set_policy = 5 [default = SET];
|
||||
optional fixed32 expiration_time = 6 [default = 0];
|
||||
|
||||
optional fixed64 cas_id = 8;
|
||||
optional bool for_cas = 9;
|
||||
}
|
||||
optional string name_space = 7 [default = ""];
|
||||
optional AppOverride override = 10;
|
||||
}
|
||||
|
||||
message MemcacheSetResponse {
|
||||
enum SetStatusCode {
|
||||
STORED = 1;
|
||||
NOT_STORED = 2;
|
||||
ERROR = 3;
|
||||
EXISTS = 4;
|
||||
}
|
||||
repeated SetStatusCode set_status = 1;
|
||||
}
|
||||
|
||||
message MemcacheDeleteRequest {
|
||||
repeated group Item = 1 {
|
||||
required bytes key = 2;
|
||||
optional fixed32 delete_time = 3 [default = 0];
|
||||
}
|
||||
optional string name_space = 4 [default = ""];
|
||||
optional AppOverride override = 5;
|
||||
}
|
||||
|
||||
message MemcacheDeleteResponse {
|
||||
enum DeleteStatusCode {
|
||||
DELETED = 1;
|
||||
NOT_FOUND = 2;
|
||||
}
|
||||
repeated DeleteStatusCode delete_status = 1;
|
||||
}
|
||||
|
||||
message MemcacheIncrementRequest {
|
||||
enum Direction {
|
||||
INCREMENT = 1;
|
||||
DECREMENT = 2;
|
||||
}
|
||||
required bytes key = 1;
|
||||
optional string name_space = 4 [default = ""];
|
||||
|
||||
optional uint64 delta = 2 [default = 1];
|
||||
optional Direction direction = 3 [default = INCREMENT];
|
||||
|
||||
optional uint64 initial_value = 5;
|
||||
optional fixed32 initial_flags = 6;
|
||||
optional AppOverride override = 7;
|
||||
}
|
||||
|
||||
message MemcacheIncrementResponse {
|
||||
enum IncrementStatusCode {
|
||||
OK = 1;
|
||||
NOT_CHANGED = 2;
|
||||
ERROR = 3;
|
||||
}
|
||||
|
||||
optional uint64 new_value = 1;
|
||||
optional IncrementStatusCode increment_status = 2;
|
||||
}
|
||||
|
||||
message MemcacheBatchIncrementRequest {
|
||||
optional string name_space = 1 [default = ""];
|
||||
repeated MemcacheIncrementRequest item = 2;
|
||||
optional AppOverride override = 3;
|
||||
}
|
||||
|
||||
message MemcacheBatchIncrementResponse {
|
||||
repeated MemcacheIncrementResponse item = 1;
|
||||
}
|
||||
|
||||
message MemcacheFlushRequest {
|
||||
optional AppOverride override = 1;
|
||||
}
|
||||
|
||||
message MemcacheFlushResponse {
|
||||
}
|
||||
|
||||
message MemcacheStatsRequest {
|
||||
optional AppOverride override = 1;
|
||||
}
|
||||
|
||||
message MergedNamespaceStats {
|
||||
required uint64 hits = 1;
|
||||
required uint64 misses = 2;
|
||||
required uint64 byte_hits = 3;
|
||||
|
||||
required uint64 items = 4;
|
||||
required uint64 bytes = 5;
|
||||
|
||||
required fixed32 oldest_item_age = 6;
|
||||
}
|
||||
|
||||
message MemcacheStatsResponse {
|
||||
optional MergedNamespaceStats stats = 1;
|
||||
}
|
||||
|
||||
message MemcacheGrabTailRequest {
|
||||
required int32 item_count = 1;
|
||||
optional string name_space = 2 [default = ""];
|
||||
optional AppOverride override = 3;
|
||||
}
|
||||
|
||||
message MemcacheGrabTailResponse {
|
||||
repeated group Item = 1 {
|
||||
required bytes value = 2;
|
||||
optional fixed32 flags = 3;
|
||||
}
|
||||
}
|
61
vendor/google.golang.org/appengine/internal/metadata.go
generated
vendored
Normal file
61
vendor/google.golang.org/appengine/internal/metadata.go
generated
vendored
Normal file
@@ -0,0 +1,61 @@
|
||||
// Copyright 2014 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
package internal
|
||||
|
||||
// This file has code for accessing metadata.
|
||||
//
|
||||
// References:
|
||||
// https://cloud.google.com/compute/docs/metadata
|
||||
|
||||
import (
|
||||
"fmt"
|
||||
"io/ioutil"
|
||||
"log"
|
||||
"net/http"
|
||||
"net/url"
|
||||
)
|
||||
|
||||
const (
|
||||
metadataHost = "metadata"
|
||||
metadataPath = "/computeMetadata/v1/"
|
||||
)
|
||||
|
||||
var (
|
||||
metadataRequestHeaders = http.Header{
|
||||
"Metadata-Flavor": []string{"Google"},
|
||||
}
|
||||
)
|
||||
|
||||
// TODO(dsymonds): Do we need to support default values, like Python?
|
||||
func mustGetMetadata(key string) []byte {
|
||||
b, err := getMetadata(key)
|
||||
if err != nil {
|
||||
log.Fatalf("Metadata fetch failed: %v", err)
|
||||
}
|
||||
return b
|
||||
}
|
||||
|
||||
func getMetadata(key string) ([]byte, error) {
|
||||
// TODO(dsymonds): May need to use url.Parse to support keys with query args.
|
||||
req := &http.Request{
|
||||
Method: "GET",
|
||||
URL: &url.URL{
|
||||
Scheme: "http",
|
||||
Host: metadataHost,
|
||||
Path: metadataPath + key,
|
||||
},
|
||||
Header: metadataRequestHeaders,
|
||||
Host: metadataHost,
|
||||
}
|
||||
resp, err := http.DefaultClient.Do(req)
|
||||
if err != nil {
|
||||
return nil, err
|
||||
}
|
||||
defer resp.Body.Close()
|
||||
if resp.StatusCode != 200 {
|
||||
return nil, fmt.Errorf("metadata server returned HTTP %d", resp.StatusCode)
|
||||
}
|
||||
return ioutil.ReadAll(resp.Body)
|
||||
}
|
375
vendor/google.golang.org/appengine/internal/modules/modules_service.pb.go
generated
vendored
Normal file
375
vendor/google.golang.org/appengine/internal/modules/modules_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,375 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/modules/modules_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package modules is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/modules/modules_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
ModulesServiceError
|
||||
GetModulesRequest
|
||||
GetModulesResponse
|
||||
GetVersionsRequest
|
||||
GetVersionsResponse
|
||||
GetDefaultVersionRequest
|
||||
GetDefaultVersionResponse
|
||||
GetNumInstancesRequest
|
||||
GetNumInstancesResponse
|
||||
SetNumInstancesRequest
|
||||
SetNumInstancesResponse
|
||||
StartModuleRequest
|
||||
StartModuleResponse
|
||||
StopModuleRequest
|
||||
StopModuleResponse
|
||||
GetHostnameRequest
|
||||
GetHostnameResponse
|
||||
*/
|
||||
package modules
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type ModulesServiceError_ErrorCode int32
|
||||
|
||||
const (
|
||||
ModulesServiceError_OK ModulesServiceError_ErrorCode = 0
|
||||
ModulesServiceError_INVALID_MODULE ModulesServiceError_ErrorCode = 1
|
||||
ModulesServiceError_INVALID_VERSION ModulesServiceError_ErrorCode = 2
|
||||
ModulesServiceError_INVALID_INSTANCES ModulesServiceError_ErrorCode = 3
|
||||
ModulesServiceError_TRANSIENT_ERROR ModulesServiceError_ErrorCode = 4
|
||||
ModulesServiceError_UNEXPECTED_STATE ModulesServiceError_ErrorCode = 5
|
||||
)
|
||||
|
||||
var ModulesServiceError_ErrorCode_name = map[int32]string{
|
||||
0: "OK",
|
||||
1: "INVALID_MODULE",
|
||||
2: "INVALID_VERSION",
|
||||
3: "INVALID_INSTANCES",
|
||||
4: "TRANSIENT_ERROR",
|
||||
5: "UNEXPECTED_STATE",
|
||||
}
|
||||
var ModulesServiceError_ErrorCode_value = map[string]int32{
|
||||
"OK": 0,
|
||||
"INVALID_MODULE": 1,
|
||||
"INVALID_VERSION": 2,
|
||||
"INVALID_INSTANCES": 3,
|
||||
"TRANSIENT_ERROR": 4,
|
||||
"UNEXPECTED_STATE": 5,
|
||||
}
|
||||
|
||||
func (x ModulesServiceError_ErrorCode) Enum() *ModulesServiceError_ErrorCode {
|
||||
p := new(ModulesServiceError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x ModulesServiceError_ErrorCode) String() string {
|
||||
return proto.EnumName(ModulesServiceError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *ModulesServiceError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(ModulesServiceError_ErrorCode_value, data, "ModulesServiceError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = ModulesServiceError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type ModulesServiceError struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ModulesServiceError) Reset() { *m = ModulesServiceError{} }
|
||||
func (m *ModulesServiceError) String() string { return proto.CompactTextString(m) }
|
||||
func (*ModulesServiceError) ProtoMessage() {}
|
||||
|
||||
type GetModulesRequest struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetModulesRequest) Reset() { *m = GetModulesRequest{} }
|
||||
func (m *GetModulesRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetModulesRequest) ProtoMessage() {}
|
||||
|
||||
type GetModulesResponse struct {
|
||||
Module []string `protobuf:"bytes,1,rep,name=module" json:"module,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetModulesResponse) Reset() { *m = GetModulesResponse{} }
|
||||
func (m *GetModulesResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetModulesResponse) ProtoMessage() {}
|
||||
|
||||
func (m *GetModulesResponse) GetModule() []string {
|
||||
if m != nil {
|
||||
return m.Module
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type GetVersionsRequest struct {
|
||||
Module *string `protobuf:"bytes,1,opt,name=module" json:"module,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetVersionsRequest) Reset() { *m = GetVersionsRequest{} }
|
||||
func (m *GetVersionsRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetVersionsRequest) ProtoMessage() {}
|
||||
|
||||
func (m *GetVersionsRequest) GetModule() string {
|
||||
if m != nil && m.Module != nil {
|
||||
return *m.Module
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type GetVersionsResponse struct {
|
||||
Version []string `protobuf:"bytes,1,rep,name=version" json:"version,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetVersionsResponse) Reset() { *m = GetVersionsResponse{} }
|
||||
func (m *GetVersionsResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetVersionsResponse) ProtoMessage() {}
|
||||
|
||||
func (m *GetVersionsResponse) GetVersion() []string {
|
||||
if m != nil {
|
||||
return m.Version
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type GetDefaultVersionRequest struct {
|
||||
Module *string `protobuf:"bytes,1,opt,name=module" json:"module,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetDefaultVersionRequest) Reset() { *m = GetDefaultVersionRequest{} }
|
||||
func (m *GetDefaultVersionRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetDefaultVersionRequest) ProtoMessage() {}
|
||||
|
||||
func (m *GetDefaultVersionRequest) GetModule() string {
|
||||
if m != nil && m.Module != nil {
|
||||
return *m.Module
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type GetDefaultVersionResponse struct {
|
||||
Version *string `protobuf:"bytes,1,req,name=version" json:"version,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetDefaultVersionResponse) Reset() { *m = GetDefaultVersionResponse{} }
|
||||
func (m *GetDefaultVersionResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetDefaultVersionResponse) ProtoMessage() {}
|
||||
|
||||
func (m *GetDefaultVersionResponse) GetVersion() string {
|
||||
if m != nil && m.Version != nil {
|
||||
return *m.Version
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type GetNumInstancesRequest struct {
|
||||
Module *string `protobuf:"bytes,1,opt,name=module" json:"module,omitempty"`
|
||||
Version *string `protobuf:"bytes,2,opt,name=version" json:"version,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetNumInstancesRequest) Reset() { *m = GetNumInstancesRequest{} }
|
||||
func (m *GetNumInstancesRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetNumInstancesRequest) ProtoMessage() {}
|
||||
|
||||
func (m *GetNumInstancesRequest) GetModule() string {
|
||||
if m != nil && m.Module != nil {
|
||||
return *m.Module
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *GetNumInstancesRequest) GetVersion() string {
|
||||
if m != nil && m.Version != nil {
|
||||
return *m.Version
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type GetNumInstancesResponse struct {
|
||||
Instances *int64 `protobuf:"varint,1,req,name=instances" json:"instances,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetNumInstancesResponse) Reset() { *m = GetNumInstancesResponse{} }
|
||||
func (m *GetNumInstancesResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetNumInstancesResponse) ProtoMessage() {}
|
||||
|
||||
func (m *GetNumInstancesResponse) GetInstances() int64 {
|
||||
if m != nil && m.Instances != nil {
|
||||
return *m.Instances
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type SetNumInstancesRequest struct {
|
||||
Module *string `protobuf:"bytes,1,opt,name=module" json:"module,omitempty"`
|
||||
Version *string `protobuf:"bytes,2,opt,name=version" json:"version,omitempty"`
|
||||
Instances *int64 `protobuf:"varint,3,req,name=instances" json:"instances,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *SetNumInstancesRequest) Reset() { *m = SetNumInstancesRequest{} }
|
||||
func (m *SetNumInstancesRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*SetNumInstancesRequest) ProtoMessage() {}
|
||||
|
||||
func (m *SetNumInstancesRequest) GetModule() string {
|
||||
if m != nil && m.Module != nil {
|
||||
return *m.Module
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *SetNumInstancesRequest) GetVersion() string {
|
||||
if m != nil && m.Version != nil {
|
||||
return *m.Version
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *SetNumInstancesRequest) GetInstances() int64 {
|
||||
if m != nil && m.Instances != nil {
|
||||
return *m.Instances
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type SetNumInstancesResponse struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *SetNumInstancesResponse) Reset() { *m = SetNumInstancesResponse{} }
|
||||
func (m *SetNumInstancesResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*SetNumInstancesResponse) ProtoMessage() {}
|
||||
|
||||
type StartModuleRequest struct {
|
||||
Module *string `protobuf:"bytes,1,req,name=module" json:"module,omitempty"`
|
||||
Version *string `protobuf:"bytes,2,req,name=version" json:"version,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *StartModuleRequest) Reset() { *m = StartModuleRequest{} }
|
||||
func (m *StartModuleRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*StartModuleRequest) ProtoMessage() {}
|
||||
|
||||
func (m *StartModuleRequest) GetModule() string {
|
||||
if m != nil && m.Module != nil {
|
||||
return *m.Module
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *StartModuleRequest) GetVersion() string {
|
||||
if m != nil && m.Version != nil {
|
||||
return *m.Version
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type StartModuleResponse struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *StartModuleResponse) Reset() { *m = StartModuleResponse{} }
|
||||
func (m *StartModuleResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*StartModuleResponse) ProtoMessage() {}
|
||||
|
||||
type StopModuleRequest struct {
|
||||
Module *string `protobuf:"bytes,1,opt,name=module" json:"module,omitempty"`
|
||||
Version *string `protobuf:"bytes,2,opt,name=version" json:"version,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *StopModuleRequest) Reset() { *m = StopModuleRequest{} }
|
||||
func (m *StopModuleRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*StopModuleRequest) ProtoMessage() {}
|
||||
|
||||
func (m *StopModuleRequest) GetModule() string {
|
||||
if m != nil && m.Module != nil {
|
||||
return *m.Module
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *StopModuleRequest) GetVersion() string {
|
||||
if m != nil && m.Version != nil {
|
||||
return *m.Version
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type StopModuleResponse struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *StopModuleResponse) Reset() { *m = StopModuleResponse{} }
|
||||
func (m *StopModuleResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*StopModuleResponse) ProtoMessage() {}
|
||||
|
||||
type GetHostnameRequest struct {
|
||||
Module *string `protobuf:"bytes,1,opt,name=module" json:"module,omitempty"`
|
||||
Version *string `protobuf:"bytes,2,opt,name=version" json:"version,omitempty"`
|
||||
Instance *string `protobuf:"bytes,3,opt,name=instance" json:"instance,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetHostnameRequest) Reset() { *m = GetHostnameRequest{} }
|
||||
func (m *GetHostnameRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetHostnameRequest) ProtoMessage() {}
|
||||
|
||||
func (m *GetHostnameRequest) GetModule() string {
|
||||
if m != nil && m.Module != nil {
|
||||
return *m.Module
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *GetHostnameRequest) GetVersion() string {
|
||||
if m != nil && m.Version != nil {
|
||||
return *m.Version
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *GetHostnameRequest) GetInstance() string {
|
||||
if m != nil && m.Instance != nil {
|
||||
return *m.Instance
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type GetHostnameResponse struct {
|
||||
Hostname *string `protobuf:"bytes,1,req,name=hostname" json:"hostname,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetHostnameResponse) Reset() { *m = GetHostnameResponse{} }
|
||||
func (m *GetHostnameResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetHostnameResponse) ProtoMessage() {}
|
||||
|
||||
func (m *GetHostnameResponse) GetHostname() string {
|
||||
if m != nil && m.Hostname != nil {
|
||||
return *m.Hostname
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func init() {
|
||||
}
|
80
vendor/google.golang.org/appengine/internal/modules/modules_service.proto
generated
vendored
Normal file
80
vendor/google.golang.org/appengine/internal/modules/modules_service.proto
generated
vendored
Normal file
@@ -0,0 +1,80 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "modules";
|
||||
|
||||
package appengine;
|
||||
|
||||
message ModulesServiceError {
|
||||
enum ErrorCode {
|
||||
OK = 0;
|
||||
INVALID_MODULE = 1;
|
||||
INVALID_VERSION = 2;
|
||||
INVALID_INSTANCES = 3;
|
||||
TRANSIENT_ERROR = 4;
|
||||
UNEXPECTED_STATE = 5;
|
||||
}
|
||||
}
|
||||
|
||||
message GetModulesRequest {
|
||||
}
|
||||
|
||||
message GetModulesResponse {
|
||||
repeated string module = 1;
|
||||
}
|
||||
|
||||
message GetVersionsRequest {
|
||||
optional string module = 1;
|
||||
}
|
||||
|
||||
message GetVersionsResponse {
|
||||
repeated string version = 1;
|
||||
}
|
||||
|
||||
message GetDefaultVersionRequest {
|
||||
optional string module = 1;
|
||||
}
|
||||
|
||||
message GetDefaultVersionResponse {
|
||||
required string version = 1;
|
||||
}
|
||||
|
||||
message GetNumInstancesRequest {
|
||||
optional string module = 1;
|
||||
optional string version = 2;
|
||||
}
|
||||
|
||||
message GetNumInstancesResponse {
|
||||
required int64 instances = 1;
|
||||
}
|
||||
|
||||
message SetNumInstancesRequest {
|
||||
optional string module = 1;
|
||||
optional string version = 2;
|
||||
required int64 instances = 3;
|
||||
}
|
||||
|
||||
message SetNumInstancesResponse {}
|
||||
|
||||
message StartModuleRequest {
|
||||
required string module = 1;
|
||||
required string version = 2;
|
||||
}
|
||||
|
||||
message StartModuleResponse {}
|
||||
|
||||
message StopModuleRequest {
|
||||
optional string module = 1;
|
||||
optional string version = 2;
|
||||
}
|
||||
|
||||
message StopModuleResponse {}
|
||||
|
||||
message GetHostnameRequest {
|
||||
optional string module = 1;
|
||||
optional string version = 2;
|
||||
optional string instance = 3;
|
||||
}
|
||||
|
||||
message GetHostnameResponse {
|
||||
required string hostname = 1;
|
||||
}
|
||||
|
56
vendor/google.golang.org/appengine/internal/net.go
generated
vendored
Normal file
56
vendor/google.golang.org/appengine/internal/net.go
generated
vendored
Normal file
@@ -0,0 +1,56 @@
|
||||
// Copyright 2014 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
package internal
|
||||
|
||||
// This file implements a network dialer that limits the number of concurrent connections.
|
||||
// It is only used for API calls.
|
||||
|
||||
import (
|
||||
"log"
|
||||
"net"
|
||||
"runtime"
|
||||
"sync"
|
||||
"time"
|
||||
)
|
||||
|
||||
var limitSem = make(chan int, 100) // TODO(dsymonds): Use environment variable.
|
||||
|
||||
func limitRelease() {
|
||||
// non-blocking
|
||||
select {
|
||||
case <-limitSem:
|
||||
default:
|
||||
// This should not normally happen.
|
||||
log.Print("appengine: unbalanced limitSem release!")
|
||||
}
|
||||
}
|
||||
|
||||
func limitDial(network, addr string) (net.Conn, error) {
|
||||
limitSem <- 1
|
||||
|
||||
// Dial with a timeout in case the API host is MIA.
|
||||
// The connection should normally be very fast.
|
||||
conn, err := net.DialTimeout(network, addr, 500*time.Millisecond)
|
||||
if err != nil {
|
||||
limitRelease()
|
||||
return nil, err
|
||||
}
|
||||
lc := &limitConn{Conn: conn}
|
||||
runtime.SetFinalizer(lc, (*limitConn).Close) // shouldn't usually be required
|
||||
return lc, nil
|
||||
}
|
||||
|
||||
type limitConn struct {
|
||||
close sync.Once
|
||||
net.Conn
|
||||
}
|
||||
|
||||
func (lc *limitConn) Close() error {
|
||||
defer lc.close.Do(func() {
|
||||
limitRelease()
|
||||
runtime.SetFinalizer(lc, nil)
|
||||
})
|
||||
return lc.Conn.Close()
|
||||
}
|
58
vendor/google.golang.org/appengine/internal/net_test.go
generated
vendored
Normal file
58
vendor/google.golang.org/appengine/internal/net_test.go
generated
vendored
Normal file
@@ -0,0 +1,58 @@
|
||||
// Copyright 2014 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
// +build !appengine
|
||||
|
||||
package internal
|
||||
|
||||
import (
|
||||
"sync"
|
||||
"testing"
|
||||
"time"
|
||||
|
||||
netcontext "golang.org/x/net/context"
|
||||
|
||||
basepb "google.golang.org/appengine/internal/base"
|
||||
)
|
||||
|
||||
func TestDialLimit(t *testing.T) {
|
||||
// Fill up semaphore with false acquisitions to permit only two TCP connections at a time.
|
||||
// We don't replace limitSem because that results in a data race when net/http lazily closes connections.
|
||||
nFake := cap(limitSem) - 2
|
||||
for i := 0; i < nFake; i++ {
|
||||
limitSem <- 1
|
||||
}
|
||||
defer func() {
|
||||
for i := 0; i < nFake; i++ {
|
||||
<-limitSem
|
||||
}
|
||||
}()
|
||||
|
||||
f, c, cleanup := setup() // setup is in api_test.go
|
||||
defer cleanup()
|
||||
f.hang = make(chan int)
|
||||
|
||||
// If we make two RunSlowly RPCs (which will wait for f.hang to be strobed),
|
||||
// then the simple Non200 RPC should hang.
|
||||
var wg sync.WaitGroup
|
||||
wg.Add(2)
|
||||
for i := 0; i < 2; i++ {
|
||||
go func() {
|
||||
defer wg.Done()
|
||||
Call(toContext(c), "errors", "RunSlowly", &basepb.VoidProto{}, &basepb.VoidProto{})
|
||||
}()
|
||||
}
|
||||
time.Sleep(50 * time.Millisecond) // let those two RPCs start
|
||||
|
||||
ctx, _ := netcontext.WithTimeout(toContext(c), 50*time.Millisecond)
|
||||
err := Call(ctx, "errors", "Non200", &basepb.VoidProto{}, &basepb.VoidProto{})
|
||||
if err != errTimeout {
|
||||
t.Errorf("Non200 RPC returned with err %v, want errTimeout", err)
|
||||
}
|
||||
|
||||
// Drain the two RunSlowly calls.
|
||||
f.hang <- 1
|
||||
f.hang <- 1
|
||||
wg.Wait()
|
||||
}
|
40
vendor/google.golang.org/appengine/internal/regen.sh
generated
vendored
Normal file
40
vendor/google.golang.org/appengine/internal/regen.sh
generated
vendored
Normal file
@@ -0,0 +1,40 @@
|
||||
#!/bin/bash -e
|
||||
#
|
||||
# This script rebuilds the generated code for the protocol buffers.
|
||||
# To run this you will need protoc and goprotobuf installed;
|
||||
# see https://github.com/golang/protobuf for instructions.
|
||||
|
||||
PKG=google.golang.org/appengine
|
||||
|
||||
function die() {
|
||||
echo 1>&2 $*
|
||||
exit 1
|
||||
}
|
||||
|
||||
# Sanity check that the right tools are accessible.
|
||||
for tool in go protoc protoc-gen-go; do
|
||||
q=$(which $tool) || die "didn't find $tool"
|
||||
echo 1>&2 "$tool: $q"
|
||||
done
|
||||
|
||||
echo -n 1>&2 "finding package dir... "
|
||||
pkgdir=$(go list -f '{{.Dir}}' $PKG)
|
||||
echo 1>&2 $pkgdir
|
||||
base=$(echo $pkgdir | sed "s,/$PKG\$,,")
|
||||
echo 1>&2 "base: $base"
|
||||
cd $base
|
||||
|
||||
# Run protoc once per package.
|
||||
for dir in $(find $PKG/internal -name '*.proto' | xargs dirname | sort | uniq); do
|
||||
echo 1>&2 "* $dir"
|
||||
protoc --go_out=. $dir/*.proto
|
||||
done
|
||||
|
||||
for f in $(find $PKG/internal -name '*.pb.go'); do
|
||||
# Remove proto.RegisterEnum calls.
|
||||
# These cause duplicate registration panics when these packages
|
||||
# are used on classic App Engine. proto.RegisterEnum only affects
|
||||
# parsing the text format; we don't care about that.
|
||||
# https://code.google.com/p/googleappengine/issues/detail?id=11670#c17
|
||||
sed -i '/proto.RegisterEnum/d' $f
|
||||
done
|
231
vendor/google.golang.org/appengine/internal/remote_api/remote_api.pb.go
generated
vendored
Normal file
231
vendor/google.golang.org/appengine/internal/remote_api/remote_api.pb.go
generated
vendored
Normal file
@@ -0,0 +1,231 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/remote_api/remote_api.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package remote_api is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/remote_api/remote_api.proto
|
||||
|
||||
It has these top-level messages:
|
||||
Request
|
||||
ApplicationError
|
||||
RpcError
|
||||
Response
|
||||
*/
|
||||
package remote_api
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type RpcError_ErrorCode int32
|
||||
|
||||
const (
|
||||
RpcError_UNKNOWN RpcError_ErrorCode = 0
|
||||
RpcError_CALL_NOT_FOUND RpcError_ErrorCode = 1
|
||||
RpcError_PARSE_ERROR RpcError_ErrorCode = 2
|
||||
RpcError_SECURITY_VIOLATION RpcError_ErrorCode = 3
|
||||
RpcError_OVER_QUOTA RpcError_ErrorCode = 4
|
||||
RpcError_REQUEST_TOO_LARGE RpcError_ErrorCode = 5
|
||||
RpcError_CAPABILITY_DISABLED RpcError_ErrorCode = 6
|
||||
RpcError_FEATURE_DISABLED RpcError_ErrorCode = 7
|
||||
RpcError_BAD_REQUEST RpcError_ErrorCode = 8
|
||||
RpcError_RESPONSE_TOO_LARGE RpcError_ErrorCode = 9
|
||||
RpcError_CANCELLED RpcError_ErrorCode = 10
|
||||
RpcError_REPLAY_ERROR RpcError_ErrorCode = 11
|
||||
RpcError_DEADLINE_EXCEEDED RpcError_ErrorCode = 12
|
||||
)
|
||||
|
||||
var RpcError_ErrorCode_name = map[int32]string{
|
||||
0: "UNKNOWN",
|
||||
1: "CALL_NOT_FOUND",
|
||||
2: "PARSE_ERROR",
|
||||
3: "SECURITY_VIOLATION",
|
||||
4: "OVER_QUOTA",
|
||||
5: "REQUEST_TOO_LARGE",
|
||||
6: "CAPABILITY_DISABLED",
|
||||
7: "FEATURE_DISABLED",
|
||||
8: "BAD_REQUEST",
|
||||
9: "RESPONSE_TOO_LARGE",
|
||||
10: "CANCELLED",
|
||||
11: "REPLAY_ERROR",
|
||||
12: "DEADLINE_EXCEEDED",
|
||||
}
|
||||
var RpcError_ErrorCode_value = map[string]int32{
|
||||
"UNKNOWN": 0,
|
||||
"CALL_NOT_FOUND": 1,
|
||||
"PARSE_ERROR": 2,
|
||||
"SECURITY_VIOLATION": 3,
|
||||
"OVER_QUOTA": 4,
|
||||
"REQUEST_TOO_LARGE": 5,
|
||||
"CAPABILITY_DISABLED": 6,
|
||||
"FEATURE_DISABLED": 7,
|
||||
"BAD_REQUEST": 8,
|
||||
"RESPONSE_TOO_LARGE": 9,
|
||||
"CANCELLED": 10,
|
||||
"REPLAY_ERROR": 11,
|
||||
"DEADLINE_EXCEEDED": 12,
|
||||
}
|
||||
|
||||
func (x RpcError_ErrorCode) Enum() *RpcError_ErrorCode {
|
||||
p := new(RpcError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x RpcError_ErrorCode) String() string {
|
||||
return proto.EnumName(RpcError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *RpcError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(RpcError_ErrorCode_value, data, "RpcError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = RpcError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type Request struct {
|
||||
ServiceName *string `protobuf:"bytes,2,req,name=service_name" json:"service_name,omitempty"`
|
||||
Method *string `protobuf:"bytes,3,req,name=method" json:"method,omitempty"`
|
||||
Request []byte `protobuf:"bytes,4,req,name=request" json:"request,omitempty"`
|
||||
RequestId *string `protobuf:"bytes,5,opt,name=request_id" json:"request_id,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *Request) Reset() { *m = Request{} }
|
||||
func (m *Request) String() string { return proto.CompactTextString(m) }
|
||||
func (*Request) ProtoMessage() {}
|
||||
|
||||
func (m *Request) GetServiceName() string {
|
||||
if m != nil && m.ServiceName != nil {
|
||||
return *m.ServiceName
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *Request) GetMethod() string {
|
||||
if m != nil && m.Method != nil {
|
||||
return *m.Method
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *Request) GetRequest() []byte {
|
||||
if m != nil {
|
||||
return m.Request
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *Request) GetRequestId() string {
|
||||
if m != nil && m.RequestId != nil {
|
||||
return *m.RequestId
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type ApplicationError struct {
|
||||
Code *int32 `protobuf:"varint,1,req,name=code" json:"code,omitempty"`
|
||||
Detail *string `protobuf:"bytes,2,req,name=detail" json:"detail,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *ApplicationError) Reset() { *m = ApplicationError{} }
|
||||
func (m *ApplicationError) String() string { return proto.CompactTextString(m) }
|
||||
func (*ApplicationError) ProtoMessage() {}
|
||||
|
||||
func (m *ApplicationError) GetCode() int32 {
|
||||
if m != nil && m.Code != nil {
|
||||
return *m.Code
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *ApplicationError) GetDetail() string {
|
||||
if m != nil && m.Detail != nil {
|
||||
return *m.Detail
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type RpcError struct {
|
||||
Code *int32 `protobuf:"varint,1,req,name=code" json:"code,omitempty"`
|
||||
Detail *string `protobuf:"bytes,2,opt,name=detail" json:"detail,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *RpcError) Reset() { *m = RpcError{} }
|
||||
func (m *RpcError) String() string { return proto.CompactTextString(m) }
|
||||
func (*RpcError) ProtoMessage() {}
|
||||
|
||||
func (m *RpcError) GetCode() int32 {
|
||||
if m != nil && m.Code != nil {
|
||||
return *m.Code
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *RpcError) GetDetail() string {
|
||||
if m != nil && m.Detail != nil {
|
||||
return *m.Detail
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type Response struct {
|
||||
Response []byte `protobuf:"bytes,1,opt,name=response" json:"response,omitempty"`
|
||||
Exception []byte `protobuf:"bytes,2,opt,name=exception" json:"exception,omitempty"`
|
||||
ApplicationError *ApplicationError `protobuf:"bytes,3,opt,name=application_error" json:"application_error,omitempty"`
|
||||
JavaException []byte `protobuf:"bytes,4,opt,name=java_exception" json:"java_exception,omitempty"`
|
||||
RpcError *RpcError `protobuf:"bytes,5,opt,name=rpc_error" json:"rpc_error,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *Response) Reset() { *m = Response{} }
|
||||
func (m *Response) String() string { return proto.CompactTextString(m) }
|
||||
func (*Response) ProtoMessage() {}
|
||||
|
||||
func (m *Response) GetResponse() []byte {
|
||||
if m != nil {
|
||||
return m.Response
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *Response) GetException() []byte {
|
||||
if m != nil {
|
||||
return m.Exception
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *Response) GetApplicationError() *ApplicationError {
|
||||
if m != nil {
|
||||
return m.ApplicationError
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *Response) GetJavaException() []byte {
|
||||
if m != nil {
|
||||
return m.JavaException
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *Response) GetRpcError() *RpcError {
|
||||
if m != nil {
|
||||
return m.RpcError
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func init() {
|
||||
}
|
44
vendor/google.golang.org/appengine/internal/remote_api/remote_api.proto
generated
vendored
Normal file
44
vendor/google.golang.org/appengine/internal/remote_api/remote_api.proto
generated
vendored
Normal file
@@ -0,0 +1,44 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "remote_api";
|
||||
|
||||
package remote_api;
|
||||
|
||||
message Request {
|
||||
required string service_name = 2;
|
||||
required string method = 3;
|
||||
required bytes request = 4;
|
||||
optional string request_id = 5;
|
||||
}
|
||||
|
||||
message ApplicationError {
|
||||
required int32 code = 1;
|
||||
required string detail = 2;
|
||||
}
|
||||
|
||||
message RpcError {
|
||||
enum ErrorCode {
|
||||
UNKNOWN = 0;
|
||||
CALL_NOT_FOUND = 1;
|
||||
PARSE_ERROR = 2;
|
||||
SECURITY_VIOLATION = 3;
|
||||
OVER_QUOTA = 4;
|
||||
REQUEST_TOO_LARGE = 5;
|
||||
CAPABILITY_DISABLED = 6;
|
||||
FEATURE_DISABLED = 7;
|
||||
BAD_REQUEST = 8;
|
||||
RESPONSE_TOO_LARGE = 9;
|
||||
CANCELLED = 10;
|
||||
REPLAY_ERROR = 11;
|
||||
DEADLINE_EXCEEDED = 12;
|
||||
}
|
||||
required int32 code = 1;
|
||||
optional string detail = 2;
|
||||
}
|
||||
|
||||
message Response {
|
||||
optional bytes response = 1;
|
||||
optional bytes exception = 2;
|
||||
optional ApplicationError application_error = 3;
|
||||
optional bytes java_exception = 4;
|
||||
optional RpcError rpc_error = 5;
|
||||
}
|
2127
vendor/google.golang.org/appengine/internal/search/search.pb.go
generated
vendored
Normal file
2127
vendor/google.golang.org/appengine/internal/search/search.pb.go
generated
vendored
Normal file
File diff suppressed because it is too large
Load Diff
388
vendor/google.golang.org/appengine/internal/search/search.proto
generated
vendored
Normal file
388
vendor/google.golang.org/appengine/internal/search/search.proto
generated
vendored
Normal file
@@ -0,0 +1,388 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "search";
|
||||
|
||||
package search;
|
||||
|
||||
message Scope {
|
||||
enum Type {
|
||||
USER_BY_CANONICAL_ID = 1;
|
||||
USER_BY_EMAIL = 2;
|
||||
GROUP_BY_CANONICAL_ID = 3;
|
||||
GROUP_BY_EMAIL = 4;
|
||||
GROUP_BY_DOMAIN = 5;
|
||||
ALL_USERS = 6;
|
||||
ALL_AUTHENTICATED_USERS = 7;
|
||||
}
|
||||
|
||||
optional Type type = 1;
|
||||
optional string value = 2;
|
||||
}
|
||||
|
||||
message Entry {
|
||||
enum Permission {
|
||||
READ = 1;
|
||||
WRITE = 2;
|
||||
FULL_CONTROL = 3;
|
||||
}
|
||||
|
||||
optional Scope scope = 1;
|
||||
optional Permission permission = 2;
|
||||
optional string display_name = 3;
|
||||
}
|
||||
|
||||
message AccessControlList {
|
||||
optional string owner = 1;
|
||||
repeated Entry entries = 2;
|
||||
}
|
||||
|
||||
message FieldValue {
|
||||
enum ContentType {
|
||||
TEXT = 0;
|
||||
HTML = 1;
|
||||
ATOM = 2;
|
||||
DATE = 3;
|
||||
NUMBER = 4;
|
||||
GEO = 5;
|
||||
}
|
||||
|
||||
optional ContentType type = 1 [default = TEXT];
|
||||
|
||||
optional string language = 2 [default = "en"];
|
||||
|
||||
optional string string_value = 3;
|
||||
|
||||
optional group Geo = 4 {
|
||||
required double lat = 5;
|
||||
required double lng = 6;
|
||||
}
|
||||
}
|
||||
|
||||
message Field {
|
||||
required string name = 1;
|
||||
required FieldValue value = 2;
|
||||
}
|
||||
|
||||
message FieldTypes {
|
||||
required string name = 1;
|
||||
repeated FieldValue.ContentType type = 2;
|
||||
}
|
||||
|
||||
message IndexShardSettings {
|
||||
repeated int32 prev_num_shards = 1;
|
||||
required int32 num_shards = 2 [default=1];
|
||||
repeated int32 prev_num_shards_search_false = 3;
|
||||
optional string local_replica = 4 [default = ""];
|
||||
}
|
||||
|
||||
message FacetValue {
|
||||
enum ContentType {
|
||||
ATOM = 2;
|
||||
NUMBER = 4;
|
||||
}
|
||||
|
||||
optional ContentType type = 1 [default = ATOM];
|
||||
optional string string_value = 3;
|
||||
}
|
||||
|
||||
message Facet {
|
||||
required string name = 1;
|
||||
required FacetValue value = 2;
|
||||
}
|
||||
|
||||
message DocumentMetadata {
|
||||
optional int64 version = 1;
|
||||
optional int64 committed_st_version = 2;
|
||||
}
|
||||
|
||||
message Document {
|
||||
optional string id = 1;
|
||||
optional string language = 2 [default = "en"];
|
||||
repeated Field field = 3;
|
||||
optional int32 order_id = 4;
|
||||
|
||||
enum Storage {
|
||||
DISK = 0;
|
||||
}
|
||||
|
||||
optional Storage storage = 5 [default = DISK];
|
||||
repeated Facet facet = 8;
|
||||
}
|
||||
|
||||
message SearchServiceError {
|
||||
enum ErrorCode {
|
||||
OK = 0;
|
||||
INVALID_REQUEST = 1;
|
||||
TRANSIENT_ERROR = 2;
|
||||
INTERNAL_ERROR = 3;
|
||||
PERMISSION_DENIED = 4;
|
||||
TIMEOUT = 5;
|
||||
CONCURRENT_TRANSACTION = 6;
|
||||
}
|
||||
}
|
||||
|
||||
message RequestStatus {
|
||||
required SearchServiceError.ErrorCode code = 1;
|
||||
optional string error_detail = 2;
|
||||
optional int32 canonical_code = 3;
|
||||
}
|
||||
|
||||
message IndexSpec {
|
||||
required string name = 1;
|
||||
|
||||
enum Consistency {
|
||||
GLOBAL = 0;
|
||||
PER_DOCUMENT = 1;
|
||||
}
|
||||
optional Consistency consistency = 2 [default = PER_DOCUMENT];
|
||||
|
||||
optional string namespace = 3;
|
||||
optional int32 version = 4;
|
||||
|
||||
enum Source {
|
||||
SEARCH = 0;
|
||||
DATASTORE = 1;
|
||||
CLOUD_STORAGE = 2;
|
||||
}
|
||||
optional Source source = 5 [default = SEARCH];
|
||||
|
||||
enum Mode {
|
||||
PRIORITY = 0;
|
||||
BACKGROUND = 1;
|
||||
}
|
||||
optional Mode mode = 6 [default = PRIORITY];
|
||||
}
|
||||
|
||||
message IndexMetadata {
|
||||
required IndexSpec index_spec = 1;
|
||||
|
||||
repeated FieldTypes field = 2;
|
||||
|
||||
message Storage {
|
||||
optional int64 amount_used = 1;
|
||||
optional int64 limit = 2;
|
||||
}
|
||||
optional Storage storage = 3;
|
||||
}
|
||||
|
||||
message IndexDocumentParams {
|
||||
repeated Document document = 1;
|
||||
|
||||
enum Freshness {
|
||||
SYNCHRONOUSLY = 0;
|
||||
WHEN_CONVENIENT = 1;
|
||||
}
|
||||
optional Freshness freshness = 2 [default = SYNCHRONOUSLY, deprecated=true];
|
||||
|
||||
required IndexSpec index_spec = 3;
|
||||
}
|
||||
|
||||
message IndexDocumentRequest {
|
||||
required IndexDocumentParams params = 1;
|
||||
|
||||
optional bytes app_id = 3;
|
||||
}
|
||||
|
||||
message IndexDocumentResponse {
|
||||
repeated RequestStatus status = 1;
|
||||
|
||||
repeated string doc_id = 2;
|
||||
}
|
||||
|
||||
message DeleteDocumentParams {
|
||||
repeated string doc_id = 1;
|
||||
|
||||
required IndexSpec index_spec = 2;
|
||||
}
|
||||
|
||||
message DeleteDocumentRequest {
|
||||
required DeleteDocumentParams params = 1;
|
||||
|
||||
optional bytes app_id = 3;
|
||||
}
|
||||
|
||||
message DeleteDocumentResponse {
|
||||
repeated RequestStatus status = 1;
|
||||
}
|
||||
|
||||
message ListDocumentsParams {
|
||||
required IndexSpec index_spec = 1;
|
||||
optional string start_doc_id = 2;
|
||||
optional bool include_start_doc = 3 [default = true];
|
||||
optional int32 limit = 4 [default = 100];
|
||||
optional bool keys_only = 5;
|
||||
}
|
||||
|
||||
message ListDocumentsRequest {
|
||||
required ListDocumentsParams params = 1;
|
||||
|
||||
optional bytes app_id = 2;
|
||||
}
|
||||
|
||||
message ListDocumentsResponse {
|
||||
required RequestStatus status = 1;
|
||||
|
||||
repeated Document document = 2;
|
||||
}
|
||||
|
||||
message ListIndexesParams {
|
||||
optional bool fetch_schema = 1;
|
||||
optional int32 limit = 2 [default = 20];
|
||||
optional string namespace = 3;
|
||||
optional string start_index_name = 4;
|
||||
optional bool include_start_index = 5 [default = true];
|
||||
optional string index_name_prefix = 6;
|
||||
optional int32 offset = 7;
|
||||
optional IndexSpec.Source source = 8 [default = SEARCH];
|
||||
}
|
||||
|
||||
message ListIndexesRequest {
|
||||
required ListIndexesParams params = 1;
|
||||
|
||||
optional bytes app_id = 3;
|
||||
}
|
||||
|
||||
message ListIndexesResponse {
|
||||
required RequestStatus status = 1;
|
||||
repeated IndexMetadata index_metadata = 2;
|
||||
}
|
||||
|
||||
message DeleteSchemaParams {
|
||||
optional IndexSpec.Source source = 1 [default = SEARCH];
|
||||
repeated IndexSpec index_spec = 2;
|
||||
}
|
||||
|
||||
message DeleteSchemaRequest {
|
||||
required DeleteSchemaParams params = 1;
|
||||
|
||||
optional bytes app_id = 3;
|
||||
}
|
||||
|
||||
message DeleteSchemaResponse {
|
||||
repeated RequestStatus status = 1;
|
||||
}
|
||||
|
||||
message SortSpec {
|
||||
required string sort_expression = 1;
|
||||
optional bool sort_descending = 2 [default = true];
|
||||
optional string default_value_text = 4;
|
||||
optional double default_value_numeric = 5;
|
||||
}
|
||||
|
||||
message ScorerSpec {
|
||||
enum Scorer {
|
||||
RESCORING_MATCH_SCORER = 0;
|
||||
MATCH_SCORER = 2;
|
||||
}
|
||||
optional Scorer scorer = 1 [default = MATCH_SCORER];
|
||||
|
||||
optional int32 limit = 2 [default = 1000];
|
||||
optional string match_scorer_parameters = 9;
|
||||
}
|
||||
|
||||
message FieldSpec {
|
||||
repeated string name = 1;
|
||||
|
||||
repeated group Expression = 2 {
|
||||
required string name = 3;
|
||||
required string expression = 4;
|
||||
}
|
||||
}
|
||||
|
||||
message FacetRange {
|
||||
optional string name = 1;
|
||||
optional string start = 2;
|
||||
optional string end = 3;
|
||||
}
|
||||
|
||||
message FacetRequestParam {
|
||||
optional int32 value_limit = 1;
|
||||
repeated FacetRange range = 2;
|
||||
repeated string value_constraint = 3;
|
||||
}
|
||||
|
||||
message FacetAutoDetectParam {
|
||||
optional int32 value_limit = 1 [default = 10];
|
||||
}
|
||||
|
||||
message FacetRequest {
|
||||
required string name = 1;
|
||||
optional FacetRequestParam params = 2;
|
||||
}
|
||||
|
||||
message FacetRefinement {
|
||||
required string name = 1;
|
||||
optional string value = 2;
|
||||
|
||||
message Range {
|
||||
optional string start = 1;
|
||||
optional string end = 2;
|
||||
}
|
||||
optional Range range = 3;
|
||||
}
|
||||
|
||||
message SearchParams {
|
||||
required IndexSpec index_spec = 1;
|
||||
required string query = 2;
|
||||
optional string cursor = 4;
|
||||
optional int32 offset = 11;
|
||||
|
||||
enum CursorType {
|
||||
NONE = 0;
|
||||
SINGLE = 1;
|
||||
PER_RESULT = 2;
|
||||
}
|
||||
optional CursorType cursor_type = 5 [default = NONE];
|
||||
|
||||
optional int32 limit = 6 [default = 20];
|
||||
optional int32 matched_count_accuracy = 7;
|
||||
repeated SortSpec sort_spec = 8;
|
||||
optional ScorerSpec scorer_spec = 9;
|
||||
optional FieldSpec field_spec = 10;
|
||||
optional bool keys_only = 12;
|
||||
|
||||
enum ParsingMode {
|
||||
STRICT = 0;
|
||||
RELAXED = 1;
|
||||
}
|
||||
optional ParsingMode parsing_mode = 13 [default = STRICT];
|
||||
|
||||
optional int32 auto_discover_facet_count = 15 [default = 0];
|
||||
repeated FacetRequest include_facet = 16;
|
||||
repeated FacetRefinement facet_refinement = 17;
|
||||
optional FacetAutoDetectParam facet_auto_detect_param = 18;
|
||||
optional int32 facet_depth = 19 [default=1000];
|
||||
}
|
||||
|
||||
message SearchRequest {
|
||||
required SearchParams params = 1;
|
||||
|
||||
optional bytes app_id = 3;
|
||||
}
|
||||
|
||||
message FacetResultValue {
|
||||
required string name = 1;
|
||||
required int32 count = 2;
|
||||
required FacetRefinement refinement = 3;
|
||||
}
|
||||
|
||||
message FacetResult {
|
||||
required string name = 1;
|
||||
repeated FacetResultValue value = 2;
|
||||
}
|
||||
|
||||
message SearchResult {
|
||||
required Document document = 1;
|
||||
repeated Field expression = 4;
|
||||
repeated double score = 2;
|
||||
optional string cursor = 3;
|
||||
}
|
||||
|
||||
message SearchResponse {
|
||||
repeated SearchResult result = 1;
|
||||
required int64 matched_count = 2;
|
||||
required RequestStatus status = 3;
|
||||
optional string cursor = 4;
|
||||
repeated FacetResult facet_result = 5;
|
||||
|
||||
extensions 1000 to 9999;
|
||||
}
|
1858
vendor/google.golang.org/appengine/internal/socket/socket_service.pb.go
generated
vendored
Normal file
1858
vendor/google.golang.org/appengine/internal/socket/socket_service.pb.go
generated
vendored
Normal file
File diff suppressed because it is too large
Load Diff
460
vendor/google.golang.org/appengine/internal/socket/socket_service.proto
generated
vendored
Normal file
460
vendor/google.golang.org/appengine/internal/socket/socket_service.proto
generated
vendored
Normal file
@@ -0,0 +1,460 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "socket";
|
||||
|
||||
package appengine;
|
||||
|
||||
message RemoteSocketServiceError {
|
||||
enum ErrorCode {
|
||||
SYSTEM_ERROR = 1;
|
||||
GAI_ERROR = 2;
|
||||
FAILURE = 4;
|
||||
PERMISSION_DENIED = 5;
|
||||
INVALID_REQUEST = 6;
|
||||
SOCKET_CLOSED = 7;
|
||||
}
|
||||
|
||||
enum SystemError {
|
||||
option allow_alias = true;
|
||||
|
||||
SYS_SUCCESS = 0;
|
||||
SYS_EPERM = 1;
|
||||
SYS_ENOENT = 2;
|
||||
SYS_ESRCH = 3;
|
||||
SYS_EINTR = 4;
|
||||
SYS_EIO = 5;
|
||||
SYS_ENXIO = 6;
|
||||
SYS_E2BIG = 7;
|
||||
SYS_ENOEXEC = 8;
|
||||
SYS_EBADF = 9;
|
||||
SYS_ECHILD = 10;
|
||||
SYS_EAGAIN = 11;
|
||||
SYS_EWOULDBLOCK = 11;
|
||||
SYS_ENOMEM = 12;
|
||||
SYS_EACCES = 13;
|
||||
SYS_EFAULT = 14;
|
||||
SYS_ENOTBLK = 15;
|
||||
SYS_EBUSY = 16;
|
||||
SYS_EEXIST = 17;
|
||||
SYS_EXDEV = 18;
|
||||
SYS_ENODEV = 19;
|
||||
SYS_ENOTDIR = 20;
|
||||
SYS_EISDIR = 21;
|
||||
SYS_EINVAL = 22;
|
||||
SYS_ENFILE = 23;
|
||||
SYS_EMFILE = 24;
|
||||
SYS_ENOTTY = 25;
|
||||
SYS_ETXTBSY = 26;
|
||||
SYS_EFBIG = 27;
|
||||
SYS_ENOSPC = 28;
|
||||
SYS_ESPIPE = 29;
|
||||
SYS_EROFS = 30;
|
||||
SYS_EMLINK = 31;
|
||||
SYS_EPIPE = 32;
|
||||
SYS_EDOM = 33;
|
||||
SYS_ERANGE = 34;
|
||||
SYS_EDEADLK = 35;
|
||||
SYS_EDEADLOCK = 35;
|
||||
SYS_ENAMETOOLONG = 36;
|
||||
SYS_ENOLCK = 37;
|
||||
SYS_ENOSYS = 38;
|
||||
SYS_ENOTEMPTY = 39;
|
||||
SYS_ELOOP = 40;
|
||||
SYS_ENOMSG = 42;
|
||||
SYS_EIDRM = 43;
|
||||
SYS_ECHRNG = 44;
|
||||
SYS_EL2NSYNC = 45;
|
||||
SYS_EL3HLT = 46;
|
||||
SYS_EL3RST = 47;
|
||||
SYS_ELNRNG = 48;
|
||||
SYS_EUNATCH = 49;
|
||||
SYS_ENOCSI = 50;
|
||||
SYS_EL2HLT = 51;
|
||||
SYS_EBADE = 52;
|
||||
SYS_EBADR = 53;
|
||||
SYS_EXFULL = 54;
|
||||
SYS_ENOANO = 55;
|
||||
SYS_EBADRQC = 56;
|
||||
SYS_EBADSLT = 57;
|
||||
SYS_EBFONT = 59;
|
||||
SYS_ENOSTR = 60;
|
||||
SYS_ENODATA = 61;
|
||||
SYS_ETIME = 62;
|
||||
SYS_ENOSR = 63;
|
||||
SYS_ENONET = 64;
|
||||
SYS_ENOPKG = 65;
|
||||
SYS_EREMOTE = 66;
|
||||
SYS_ENOLINK = 67;
|
||||
SYS_EADV = 68;
|
||||
SYS_ESRMNT = 69;
|
||||
SYS_ECOMM = 70;
|
||||
SYS_EPROTO = 71;
|
||||
SYS_EMULTIHOP = 72;
|
||||
SYS_EDOTDOT = 73;
|
||||
SYS_EBADMSG = 74;
|
||||
SYS_EOVERFLOW = 75;
|
||||
SYS_ENOTUNIQ = 76;
|
||||
SYS_EBADFD = 77;
|
||||
SYS_EREMCHG = 78;
|
||||
SYS_ELIBACC = 79;
|
||||
SYS_ELIBBAD = 80;
|
||||
SYS_ELIBSCN = 81;
|
||||
SYS_ELIBMAX = 82;
|
||||
SYS_ELIBEXEC = 83;
|
||||
SYS_EILSEQ = 84;
|
||||
SYS_ERESTART = 85;
|
||||
SYS_ESTRPIPE = 86;
|
||||
SYS_EUSERS = 87;
|
||||
SYS_ENOTSOCK = 88;
|
||||
SYS_EDESTADDRREQ = 89;
|
||||
SYS_EMSGSIZE = 90;
|
||||
SYS_EPROTOTYPE = 91;
|
||||
SYS_ENOPROTOOPT = 92;
|
||||
SYS_EPROTONOSUPPORT = 93;
|
||||
SYS_ESOCKTNOSUPPORT = 94;
|
||||
SYS_EOPNOTSUPP = 95;
|
||||
SYS_ENOTSUP = 95;
|
||||
SYS_EPFNOSUPPORT = 96;
|
||||
SYS_EAFNOSUPPORT = 97;
|
||||
SYS_EADDRINUSE = 98;
|
||||
SYS_EADDRNOTAVAIL = 99;
|
||||
SYS_ENETDOWN = 100;
|
||||
SYS_ENETUNREACH = 101;
|
||||
SYS_ENETRESET = 102;
|
||||
SYS_ECONNABORTED = 103;
|
||||
SYS_ECONNRESET = 104;
|
||||
SYS_ENOBUFS = 105;
|
||||
SYS_EISCONN = 106;
|
||||
SYS_ENOTCONN = 107;
|
||||
SYS_ESHUTDOWN = 108;
|
||||
SYS_ETOOMANYREFS = 109;
|
||||
SYS_ETIMEDOUT = 110;
|
||||
SYS_ECONNREFUSED = 111;
|
||||
SYS_EHOSTDOWN = 112;
|
||||
SYS_EHOSTUNREACH = 113;
|
||||
SYS_EALREADY = 114;
|
||||
SYS_EINPROGRESS = 115;
|
||||
SYS_ESTALE = 116;
|
||||
SYS_EUCLEAN = 117;
|
||||
SYS_ENOTNAM = 118;
|
||||
SYS_ENAVAIL = 119;
|
||||
SYS_EISNAM = 120;
|
||||
SYS_EREMOTEIO = 121;
|
||||
SYS_EDQUOT = 122;
|
||||
SYS_ENOMEDIUM = 123;
|
||||
SYS_EMEDIUMTYPE = 124;
|
||||
SYS_ECANCELED = 125;
|
||||
SYS_ENOKEY = 126;
|
||||
SYS_EKEYEXPIRED = 127;
|
||||
SYS_EKEYREVOKED = 128;
|
||||
SYS_EKEYREJECTED = 129;
|
||||
SYS_EOWNERDEAD = 130;
|
||||
SYS_ENOTRECOVERABLE = 131;
|
||||
SYS_ERFKILL = 132;
|
||||
}
|
||||
|
||||
optional int32 system_error = 1 [default=0];
|
||||
optional string error_detail = 2;
|
||||
}
|
||||
|
||||
message AddressPort {
|
||||
required int32 port = 1;
|
||||
optional bytes packed_address = 2;
|
||||
|
||||
optional string hostname_hint = 3;
|
||||
}
|
||||
|
||||
|
||||
|
||||
message CreateSocketRequest {
|
||||
enum SocketFamily {
|
||||
IPv4 = 1;
|
||||
IPv6 = 2;
|
||||
}
|
||||
|
||||
enum SocketProtocol {
|
||||
TCP = 1;
|
||||
UDP = 2;
|
||||
}
|
||||
|
||||
required SocketFamily family = 1;
|
||||
required SocketProtocol protocol = 2;
|
||||
|
||||
repeated SocketOption socket_options = 3;
|
||||
|
||||
optional AddressPort proxy_external_ip = 4;
|
||||
|
||||
optional int32 listen_backlog = 5 [default=0];
|
||||
|
||||
optional AddressPort remote_ip = 6;
|
||||
|
||||
optional string app_id = 9;
|
||||
|
||||
optional int64 project_id = 10;
|
||||
}
|
||||
|
||||
message CreateSocketReply {
|
||||
optional string socket_descriptor = 1;
|
||||
|
||||
optional AddressPort server_address = 3;
|
||||
|
||||
optional AddressPort proxy_external_ip = 4;
|
||||
|
||||
extensions 1000 to max;
|
||||
}
|
||||
|
||||
|
||||
|
||||
message BindRequest {
|
||||
required string socket_descriptor = 1;
|
||||
required AddressPort proxy_external_ip = 2;
|
||||
}
|
||||
|
||||
message BindReply {
|
||||
optional AddressPort proxy_external_ip = 1;
|
||||
}
|
||||
|
||||
|
||||
|
||||
message GetSocketNameRequest {
|
||||
required string socket_descriptor = 1;
|
||||
}
|
||||
|
||||
message GetSocketNameReply {
|
||||
optional AddressPort proxy_external_ip = 2;
|
||||
}
|
||||
|
||||
|
||||
|
||||
message GetPeerNameRequest {
|
||||
required string socket_descriptor = 1;
|
||||
}
|
||||
|
||||
message GetPeerNameReply {
|
||||
optional AddressPort peer_ip = 2;
|
||||
}
|
||||
|
||||
|
||||
message SocketOption {
|
||||
|
||||
enum SocketOptionLevel {
|
||||
SOCKET_SOL_IP = 0;
|
||||
SOCKET_SOL_SOCKET = 1;
|
||||
SOCKET_SOL_TCP = 6;
|
||||
SOCKET_SOL_UDP = 17;
|
||||
}
|
||||
|
||||
enum SocketOptionName {
|
||||
option allow_alias = true;
|
||||
|
||||
SOCKET_SO_DEBUG = 1;
|
||||
SOCKET_SO_REUSEADDR = 2;
|
||||
SOCKET_SO_TYPE = 3;
|
||||
SOCKET_SO_ERROR = 4;
|
||||
SOCKET_SO_DONTROUTE = 5;
|
||||
SOCKET_SO_BROADCAST = 6;
|
||||
SOCKET_SO_SNDBUF = 7;
|
||||
SOCKET_SO_RCVBUF = 8;
|
||||
SOCKET_SO_KEEPALIVE = 9;
|
||||
SOCKET_SO_OOBINLINE = 10;
|
||||
SOCKET_SO_LINGER = 13;
|
||||
SOCKET_SO_RCVTIMEO = 20;
|
||||
SOCKET_SO_SNDTIMEO = 21;
|
||||
|
||||
SOCKET_IP_TOS = 1;
|
||||
SOCKET_IP_TTL = 2;
|
||||
SOCKET_IP_HDRINCL = 3;
|
||||
SOCKET_IP_OPTIONS = 4;
|
||||
|
||||
SOCKET_TCP_NODELAY = 1;
|
||||
SOCKET_TCP_MAXSEG = 2;
|
||||
SOCKET_TCP_CORK = 3;
|
||||
SOCKET_TCP_KEEPIDLE = 4;
|
||||
SOCKET_TCP_KEEPINTVL = 5;
|
||||
SOCKET_TCP_KEEPCNT = 6;
|
||||
SOCKET_TCP_SYNCNT = 7;
|
||||
SOCKET_TCP_LINGER2 = 8;
|
||||
SOCKET_TCP_DEFER_ACCEPT = 9;
|
||||
SOCKET_TCP_WINDOW_CLAMP = 10;
|
||||
SOCKET_TCP_INFO = 11;
|
||||
SOCKET_TCP_QUICKACK = 12;
|
||||
}
|
||||
|
||||
required SocketOptionLevel level = 1;
|
||||
required SocketOptionName option = 2;
|
||||
required bytes value = 3;
|
||||
}
|
||||
|
||||
|
||||
message SetSocketOptionsRequest {
|
||||
required string socket_descriptor = 1;
|
||||
repeated SocketOption options = 2;
|
||||
}
|
||||
|
||||
message SetSocketOptionsReply {
|
||||
}
|
||||
|
||||
message GetSocketOptionsRequest {
|
||||
required string socket_descriptor = 1;
|
||||
repeated SocketOption options = 2;
|
||||
}
|
||||
|
||||
message GetSocketOptionsReply {
|
||||
repeated SocketOption options = 2;
|
||||
}
|
||||
|
||||
|
||||
message ConnectRequest {
|
||||
required string socket_descriptor = 1;
|
||||
required AddressPort remote_ip = 2;
|
||||
optional double timeout_seconds = 3 [default=-1];
|
||||
}
|
||||
|
||||
message ConnectReply {
|
||||
optional AddressPort proxy_external_ip = 1;
|
||||
|
||||
extensions 1000 to max;
|
||||
}
|
||||
|
||||
|
||||
message ListenRequest {
|
||||
required string socket_descriptor = 1;
|
||||
required int32 backlog = 2;
|
||||
}
|
||||
|
||||
message ListenReply {
|
||||
}
|
||||
|
||||
|
||||
message AcceptRequest {
|
||||
required string socket_descriptor = 1;
|
||||
optional double timeout_seconds = 2 [default=-1];
|
||||
}
|
||||
|
||||
message AcceptReply {
|
||||
optional bytes new_socket_descriptor = 2;
|
||||
optional AddressPort remote_address = 3;
|
||||
}
|
||||
|
||||
|
||||
|
||||
message ShutDownRequest {
|
||||
enum How {
|
||||
SOCKET_SHUT_RD = 1;
|
||||
SOCKET_SHUT_WR = 2;
|
||||
SOCKET_SHUT_RDWR = 3;
|
||||
}
|
||||
required string socket_descriptor = 1;
|
||||
required How how = 2;
|
||||
required int64 send_offset = 3;
|
||||
}
|
||||
|
||||
message ShutDownReply {
|
||||
}
|
||||
|
||||
|
||||
|
||||
message CloseRequest {
|
||||
required string socket_descriptor = 1;
|
||||
optional int64 send_offset = 2 [default=-1];
|
||||
}
|
||||
|
||||
message CloseReply {
|
||||
}
|
||||
|
||||
|
||||
|
||||
message SendRequest {
|
||||
required string socket_descriptor = 1;
|
||||
required bytes data = 2 [ctype=CORD];
|
||||
required int64 stream_offset = 3;
|
||||
optional int32 flags = 4 [default=0];
|
||||
optional AddressPort send_to = 5;
|
||||
optional double timeout_seconds = 6 [default=-1];
|
||||
}
|
||||
|
||||
message SendReply {
|
||||
optional int32 data_sent = 1;
|
||||
}
|
||||
|
||||
|
||||
message ReceiveRequest {
|
||||
enum Flags {
|
||||
MSG_OOB = 1;
|
||||
MSG_PEEK = 2;
|
||||
}
|
||||
required string socket_descriptor = 1;
|
||||
required int32 data_size = 2;
|
||||
optional int32 flags = 3 [default=0];
|
||||
optional double timeout_seconds = 5 [default=-1];
|
||||
}
|
||||
|
||||
message ReceiveReply {
|
||||
optional int64 stream_offset = 2;
|
||||
optional bytes data = 3 [ctype=CORD];
|
||||
optional AddressPort received_from = 4;
|
||||
optional int32 buffer_size = 5;
|
||||
}
|
||||
|
||||
|
||||
|
||||
message PollEvent {
|
||||
|
||||
enum PollEventFlag {
|
||||
SOCKET_POLLNONE = 0;
|
||||
SOCKET_POLLIN = 1;
|
||||
SOCKET_POLLPRI = 2;
|
||||
SOCKET_POLLOUT = 4;
|
||||
SOCKET_POLLERR = 8;
|
||||
SOCKET_POLLHUP = 16;
|
||||
SOCKET_POLLNVAL = 32;
|
||||
SOCKET_POLLRDNORM = 64;
|
||||
SOCKET_POLLRDBAND = 128;
|
||||
SOCKET_POLLWRNORM = 256;
|
||||
SOCKET_POLLWRBAND = 512;
|
||||
SOCKET_POLLMSG = 1024;
|
||||
SOCKET_POLLREMOVE = 4096;
|
||||
SOCKET_POLLRDHUP = 8192;
|
||||
};
|
||||
|
||||
required string socket_descriptor = 1;
|
||||
required int32 requested_events = 2;
|
||||
required int32 observed_events = 3;
|
||||
}
|
||||
|
||||
message PollRequest {
|
||||
repeated PollEvent events = 1;
|
||||
optional double timeout_seconds = 2 [default=-1];
|
||||
}
|
||||
|
||||
message PollReply {
|
||||
repeated PollEvent events = 2;
|
||||
}
|
||||
|
||||
message ResolveRequest {
|
||||
required string name = 1;
|
||||
repeated CreateSocketRequest.SocketFamily address_families = 2;
|
||||
}
|
||||
|
||||
message ResolveReply {
|
||||
enum ErrorCode {
|
||||
SOCKET_EAI_ADDRFAMILY = 1;
|
||||
SOCKET_EAI_AGAIN = 2;
|
||||
SOCKET_EAI_BADFLAGS = 3;
|
||||
SOCKET_EAI_FAIL = 4;
|
||||
SOCKET_EAI_FAMILY = 5;
|
||||
SOCKET_EAI_MEMORY = 6;
|
||||
SOCKET_EAI_NODATA = 7;
|
||||
SOCKET_EAI_NONAME = 8;
|
||||
SOCKET_EAI_SERVICE = 9;
|
||||
SOCKET_EAI_SOCKTYPE = 10;
|
||||
SOCKET_EAI_SYSTEM = 11;
|
||||
SOCKET_EAI_BADHINTS = 12;
|
||||
SOCKET_EAI_PROTOCOL = 13;
|
||||
SOCKET_EAI_OVERFLOW = 14;
|
||||
SOCKET_EAI_MAX = 15;
|
||||
};
|
||||
|
||||
repeated bytes packed_address = 2;
|
||||
optional string canonical_name = 3;
|
||||
repeated string aliases = 4;
|
||||
}
|
198
vendor/google.golang.org/appengine/internal/system/system_service.pb.go
generated
vendored
Normal file
198
vendor/google.golang.org/appengine/internal/system/system_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,198 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/system/system_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package system is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/system/system_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
SystemServiceError
|
||||
SystemStat
|
||||
GetSystemStatsRequest
|
||||
GetSystemStatsResponse
|
||||
StartBackgroundRequestRequest
|
||||
StartBackgroundRequestResponse
|
||||
*/
|
||||
package system
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type SystemServiceError_ErrorCode int32
|
||||
|
||||
const (
|
||||
SystemServiceError_OK SystemServiceError_ErrorCode = 0
|
||||
SystemServiceError_INTERNAL_ERROR SystemServiceError_ErrorCode = 1
|
||||
SystemServiceError_BACKEND_REQUIRED SystemServiceError_ErrorCode = 2
|
||||
SystemServiceError_LIMIT_REACHED SystemServiceError_ErrorCode = 3
|
||||
)
|
||||
|
||||
var SystemServiceError_ErrorCode_name = map[int32]string{
|
||||
0: "OK",
|
||||
1: "INTERNAL_ERROR",
|
||||
2: "BACKEND_REQUIRED",
|
||||
3: "LIMIT_REACHED",
|
||||
}
|
||||
var SystemServiceError_ErrorCode_value = map[string]int32{
|
||||
"OK": 0,
|
||||
"INTERNAL_ERROR": 1,
|
||||
"BACKEND_REQUIRED": 2,
|
||||
"LIMIT_REACHED": 3,
|
||||
}
|
||||
|
||||
func (x SystemServiceError_ErrorCode) Enum() *SystemServiceError_ErrorCode {
|
||||
p := new(SystemServiceError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x SystemServiceError_ErrorCode) String() string {
|
||||
return proto.EnumName(SystemServiceError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *SystemServiceError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(SystemServiceError_ErrorCode_value, data, "SystemServiceError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = SystemServiceError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type SystemServiceError struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *SystemServiceError) Reset() { *m = SystemServiceError{} }
|
||||
func (m *SystemServiceError) String() string { return proto.CompactTextString(m) }
|
||||
func (*SystemServiceError) ProtoMessage() {}
|
||||
|
||||
type SystemStat struct {
|
||||
// Instaneous value of this stat.
|
||||
Current *float64 `protobuf:"fixed64,1,opt,name=current" json:"current,omitempty"`
|
||||
// Average over time, if this stat has an instaneous value.
|
||||
Average1M *float64 `protobuf:"fixed64,3,opt,name=average1m" json:"average1m,omitempty"`
|
||||
Average10M *float64 `protobuf:"fixed64,4,opt,name=average10m" json:"average10m,omitempty"`
|
||||
// Total value, if the stat accumulates over time.
|
||||
Total *float64 `protobuf:"fixed64,2,opt,name=total" json:"total,omitempty"`
|
||||
// Rate over time, if this stat accumulates.
|
||||
Rate1M *float64 `protobuf:"fixed64,5,opt,name=rate1m" json:"rate1m,omitempty"`
|
||||
Rate10M *float64 `protobuf:"fixed64,6,opt,name=rate10m" json:"rate10m,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *SystemStat) Reset() { *m = SystemStat{} }
|
||||
func (m *SystemStat) String() string { return proto.CompactTextString(m) }
|
||||
func (*SystemStat) ProtoMessage() {}
|
||||
|
||||
func (m *SystemStat) GetCurrent() float64 {
|
||||
if m != nil && m.Current != nil {
|
||||
return *m.Current
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *SystemStat) GetAverage1M() float64 {
|
||||
if m != nil && m.Average1M != nil {
|
||||
return *m.Average1M
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *SystemStat) GetAverage10M() float64 {
|
||||
if m != nil && m.Average10M != nil {
|
||||
return *m.Average10M
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *SystemStat) GetTotal() float64 {
|
||||
if m != nil && m.Total != nil {
|
||||
return *m.Total
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *SystemStat) GetRate1M() float64 {
|
||||
if m != nil && m.Rate1M != nil {
|
||||
return *m.Rate1M
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *SystemStat) GetRate10M() float64 {
|
||||
if m != nil && m.Rate10M != nil {
|
||||
return *m.Rate10M
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
type GetSystemStatsRequest struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetSystemStatsRequest) Reset() { *m = GetSystemStatsRequest{} }
|
||||
func (m *GetSystemStatsRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetSystemStatsRequest) ProtoMessage() {}
|
||||
|
||||
type GetSystemStatsResponse struct {
|
||||
// CPU used by this instance, in mcycles.
|
||||
Cpu *SystemStat `protobuf:"bytes,1,opt,name=cpu" json:"cpu,omitempty"`
|
||||
// Physical memory (RAM) used by this instance, in megabytes.
|
||||
Memory *SystemStat `protobuf:"bytes,2,opt,name=memory" json:"memory,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetSystemStatsResponse) Reset() { *m = GetSystemStatsResponse{} }
|
||||
func (m *GetSystemStatsResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetSystemStatsResponse) ProtoMessage() {}
|
||||
|
||||
func (m *GetSystemStatsResponse) GetCpu() *SystemStat {
|
||||
if m != nil {
|
||||
return m.Cpu
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *GetSystemStatsResponse) GetMemory() *SystemStat {
|
||||
if m != nil {
|
||||
return m.Memory
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type StartBackgroundRequestRequest struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *StartBackgroundRequestRequest) Reset() { *m = StartBackgroundRequestRequest{} }
|
||||
func (m *StartBackgroundRequestRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*StartBackgroundRequestRequest) ProtoMessage() {}
|
||||
|
||||
type StartBackgroundRequestResponse struct {
|
||||
// Every /_ah/background request will have an X-AppEngine-BackgroundRequest
|
||||
// header, whose value will be equal to this parameter, the request_id.
|
||||
RequestId *string `protobuf:"bytes,1,opt,name=request_id" json:"request_id,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *StartBackgroundRequestResponse) Reset() { *m = StartBackgroundRequestResponse{} }
|
||||
func (m *StartBackgroundRequestResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*StartBackgroundRequestResponse) ProtoMessage() {}
|
||||
|
||||
func (m *StartBackgroundRequestResponse) GetRequestId() string {
|
||||
if m != nil && m.RequestId != nil {
|
||||
return *m.RequestId
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func init() {
|
||||
}
|
49
vendor/google.golang.org/appengine/internal/system/system_service.proto
generated
vendored
Normal file
49
vendor/google.golang.org/appengine/internal/system/system_service.proto
generated
vendored
Normal file
@@ -0,0 +1,49 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "system";
|
||||
|
||||
package appengine;
|
||||
|
||||
message SystemServiceError {
|
||||
enum ErrorCode {
|
||||
OK = 0;
|
||||
INTERNAL_ERROR = 1;
|
||||
BACKEND_REQUIRED = 2;
|
||||
LIMIT_REACHED = 3;
|
||||
}
|
||||
}
|
||||
|
||||
message SystemStat {
|
||||
// Instaneous value of this stat.
|
||||
optional double current = 1;
|
||||
|
||||
// Average over time, if this stat has an instaneous value.
|
||||
optional double average1m = 3;
|
||||
optional double average10m = 4;
|
||||
|
||||
// Total value, if the stat accumulates over time.
|
||||
optional double total = 2;
|
||||
|
||||
// Rate over time, if this stat accumulates.
|
||||
optional double rate1m = 5;
|
||||
optional double rate10m = 6;
|
||||
}
|
||||
|
||||
message GetSystemStatsRequest {
|
||||
}
|
||||
|
||||
message GetSystemStatsResponse {
|
||||
// CPU used by this instance, in mcycles.
|
||||
optional SystemStat cpu = 1;
|
||||
|
||||
// Physical memory (RAM) used by this instance, in megabytes.
|
||||
optional SystemStat memory = 2;
|
||||
}
|
||||
|
||||
message StartBackgroundRequestRequest {
|
||||
}
|
||||
|
||||
message StartBackgroundRequestResponse {
|
||||
// Every /_ah/background request will have an X-AppEngine-BackgroundRequest
|
||||
// header, whose value will be equal to this parameter, the request_id.
|
||||
optional string request_id = 1;
|
||||
}
|
1888
vendor/google.golang.org/appengine/internal/taskqueue/taskqueue_service.pb.go
generated
vendored
Normal file
1888
vendor/google.golang.org/appengine/internal/taskqueue/taskqueue_service.pb.go
generated
vendored
Normal file
File diff suppressed because it is too large
Load Diff
342
vendor/google.golang.org/appengine/internal/taskqueue/taskqueue_service.proto
generated
vendored
Normal file
342
vendor/google.golang.org/appengine/internal/taskqueue/taskqueue_service.proto
generated
vendored
Normal file
@@ -0,0 +1,342 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "taskqueue";
|
||||
|
||||
import "google.golang.org/appengine/internal/datastore/datastore_v3.proto";
|
||||
|
||||
package appengine;
|
||||
|
||||
message TaskQueueServiceError {
|
||||
enum ErrorCode {
|
||||
OK = 0;
|
||||
UNKNOWN_QUEUE = 1;
|
||||
TRANSIENT_ERROR = 2;
|
||||
INTERNAL_ERROR = 3;
|
||||
TASK_TOO_LARGE = 4;
|
||||
INVALID_TASK_NAME = 5;
|
||||
INVALID_QUEUE_NAME = 6;
|
||||
INVALID_URL = 7;
|
||||
INVALID_QUEUE_RATE = 8;
|
||||
PERMISSION_DENIED = 9;
|
||||
TASK_ALREADY_EXISTS = 10;
|
||||
TOMBSTONED_TASK = 11;
|
||||
INVALID_ETA = 12;
|
||||
INVALID_REQUEST = 13;
|
||||
UNKNOWN_TASK = 14;
|
||||
TOMBSTONED_QUEUE = 15;
|
||||
DUPLICATE_TASK_NAME = 16;
|
||||
SKIPPED = 17;
|
||||
TOO_MANY_TASKS = 18;
|
||||
INVALID_PAYLOAD = 19;
|
||||
INVALID_RETRY_PARAMETERS = 20;
|
||||
INVALID_QUEUE_MODE = 21;
|
||||
ACL_LOOKUP_ERROR = 22;
|
||||
TRANSACTIONAL_REQUEST_TOO_LARGE = 23;
|
||||
INCORRECT_CREATOR_NAME = 24;
|
||||
TASK_LEASE_EXPIRED = 25;
|
||||
QUEUE_PAUSED = 26;
|
||||
INVALID_TAG = 27;
|
||||
|
||||
// Reserved range for the Datastore error codes.
|
||||
// Original Datastore error code is shifted by DATASTORE_ERROR offset.
|
||||
DATASTORE_ERROR = 10000;
|
||||
}
|
||||
}
|
||||
|
||||
message TaskPayload {
|
||||
extensions 10 to max;
|
||||
option message_set_wire_format = true;
|
||||
}
|
||||
|
||||
message TaskQueueRetryParameters {
|
||||
optional int32 retry_limit = 1;
|
||||
optional int64 age_limit_sec = 2;
|
||||
|
||||
optional double min_backoff_sec = 3 [default = 0.1];
|
||||
optional double max_backoff_sec = 4 [default = 3600];
|
||||
optional int32 max_doublings = 5 [default = 16];
|
||||
}
|
||||
|
||||
message TaskQueueAcl {
|
||||
repeated bytes user_email = 1;
|
||||
repeated bytes writer_email = 2;
|
||||
}
|
||||
|
||||
message TaskQueueHttpHeader {
|
||||
required bytes key = 1;
|
||||
required bytes value = 2;
|
||||
}
|
||||
|
||||
message TaskQueueMode {
|
||||
enum Mode {
|
||||
PUSH = 0;
|
||||
PULL = 1;
|
||||
}
|
||||
}
|
||||
|
||||
message TaskQueueAddRequest {
|
||||
required bytes queue_name = 1;
|
||||
required bytes task_name = 2;
|
||||
required int64 eta_usec = 3;
|
||||
|
||||
enum RequestMethod {
|
||||
GET = 1;
|
||||
POST = 2;
|
||||
HEAD = 3;
|
||||
PUT = 4;
|
||||
DELETE = 5;
|
||||
}
|
||||
optional RequestMethod method = 5 [default=POST];
|
||||
|
||||
optional bytes url = 4;
|
||||
|
||||
repeated group Header = 6 {
|
||||
required bytes key = 7;
|
||||
required bytes value = 8;
|
||||
}
|
||||
|
||||
optional bytes body = 9 [ctype=CORD];
|
||||
optional Transaction transaction = 10;
|
||||
optional bytes app_id = 11;
|
||||
|
||||
optional group CronTimetable = 12 {
|
||||
required bytes schedule = 13;
|
||||
required bytes timezone = 14;
|
||||
}
|
||||
|
||||
optional bytes description = 15;
|
||||
optional TaskPayload payload = 16;
|
||||
optional TaskQueueRetryParameters retry_parameters = 17;
|
||||
optional TaskQueueMode.Mode mode = 18 [default=PUSH];
|
||||
optional bytes tag = 19;
|
||||
}
|
||||
|
||||
message TaskQueueAddResponse {
|
||||
optional bytes chosen_task_name = 1;
|
||||
}
|
||||
|
||||
message TaskQueueBulkAddRequest {
|
||||
repeated TaskQueueAddRequest add_request = 1;
|
||||
}
|
||||
|
||||
message TaskQueueBulkAddResponse {
|
||||
repeated group TaskResult = 1 {
|
||||
required TaskQueueServiceError.ErrorCode result = 2;
|
||||
optional bytes chosen_task_name = 3;
|
||||
}
|
||||
}
|
||||
|
||||
message TaskQueueDeleteRequest {
|
||||
required bytes queue_name = 1;
|
||||
repeated bytes task_name = 2;
|
||||
optional bytes app_id = 3;
|
||||
}
|
||||
|
||||
message TaskQueueDeleteResponse {
|
||||
repeated TaskQueueServiceError.ErrorCode result = 3;
|
||||
}
|
||||
|
||||
message TaskQueueForceRunRequest {
|
||||
optional bytes app_id = 1;
|
||||
required bytes queue_name = 2;
|
||||
required bytes task_name = 3;
|
||||
}
|
||||
|
||||
message TaskQueueForceRunResponse {
|
||||
required TaskQueueServiceError.ErrorCode result = 3;
|
||||
}
|
||||
|
||||
message TaskQueueUpdateQueueRequest {
|
||||
optional bytes app_id = 1;
|
||||
required bytes queue_name = 2;
|
||||
required double bucket_refill_per_second = 3;
|
||||
required int32 bucket_capacity = 4;
|
||||
optional string user_specified_rate = 5;
|
||||
optional TaskQueueRetryParameters retry_parameters = 6;
|
||||
optional int32 max_concurrent_requests = 7;
|
||||
optional TaskQueueMode.Mode mode = 8 [default = PUSH];
|
||||
optional TaskQueueAcl acl = 9;
|
||||
repeated TaskQueueHttpHeader header_override = 10;
|
||||
}
|
||||
|
||||
message TaskQueueUpdateQueueResponse {
|
||||
}
|
||||
|
||||
message TaskQueueFetchQueuesRequest {
|
||||
optional bytes app_id = 1;
|
||||
required int32 max_rows = 2;
|
||||
}
|
||||
|
||||
message TaskQueueFetchQueuesResponse {
|
||||
repeated group Queue = 1 {
|
||||
required bytes queue_name = 2;
|
||||
required double bucket_refill_per_second = 3;
|
||||
required double bucket_capacity = 4;
|
||||
optional string user_specified_rate = 5;
|
||||
required bool paused = 6 [default=false];
|
||||
optional TaskQueueRetryParameters retry_parameters = 7;
|
||||
optional int32 max_concurrent_requests = 8;
|
||||
optional TaskQueueMode.Mode mode = 9 [default = PUSH];
|
||||
optional TaskQueueAcl acl = 10;
|
||||
repeated TaskQueueHttpHeader header_override = 11;
|
||||
optional string creator_name = 12 [ctype=CORD, default="apphosting"];
|
||||
}
|
||||
}
|
||||
|
||||
message TaskQueueFetchQueueStatsRequest {
|
||||
optional bytes app_id = 1;
|
||||
repeated bytes queue_name = 2;
|
||||
optional int32 max_num_tasks = 3 [default = 0];
|
||||
}
|
||||
|
||||
message TaskQueueScannerQueueInfo {
|
||||
required int64 executed_last_minute = 1;
|
||||
required int64 executed_last_hour = 2;
|
||||
required double sampling_duration_seconds = 3;
|
||||
optional int32 requests_in_flight = 4;
|
||||
optional double enforced_rate = 5;
|
||||
}
|
||||
|
||||
message TaskQueueFetchQueueStatsResponse {
|
||||
repeated group QueueStats = 1 {
|
||||
required int32 num_tasks = 2;
|
||||
required int64 oldest_eta_usec = 3;
|
||||
optional TaskQueueScannerQueueInfo scanner_info = 4;
|
||||
}
|
||||
}
|
||||
message TaskQueuePauseQueueRequest {
|
||||
required bytes app_id = 1;
|
||||
required bytes queue_name = 2;
|
||||
required bool pause = 3;
|
||||
}
|
||||
|
||||
message TaskQueuePauseQueueResponse {
|
||||
}
|
||||
|
||||
message TaskQueuePurgeQueueRequest {
|
||||
optional bytes app_id = 1;
|
||||
required bytes queue_name = 2;
|
||||
}
|
||||
|
||||
message TaskQueuePurgeQueueResponse {
|
||||
}
|
||||
|
||||
message TaskQueueDeleteQueueRequest {
|
||||
required bytes app_id = 1;
|
||||
required bytes queue_name = 2;
|
||||
}
|
||||
|
||||
message TaskQueueDeleteQueueResponse {
|
||||
}
|
||||
|
||||
message TaskQueueDeleteGroupRequest {
|
||||
required bytes app_id = 1;
|
||||
}
|
||||
|
||||
message TaskQueueDeleteGroupResponse {
|
||||
}
|
||||
|
||||
message TaskQueueQueryTasksRequest {
|
||||
optional bytes app_id = 1;
|
||||
required bytes queue_name = 2;
|
||||
|
||||
optional bytes start_task_name = 3;
|
||||
optional int64 start_eta_usec = 4;
|
||||
optional bytes start_tag = 6;
|
||||
optional int32 max_rows = 5 [default = 1];
|
||||
}
|
||||
|
||||
message TaskQueueQueryTasksResponse {
|
||||
repeated group Task = 1 {
|
||||
required bytes task_name = 2;
|
||||
required int64 eta_usec = 3;
|
||||
optional bytes url = 4;
|
||||
|
||||
enum RequestMethod {
|
||||
GET = 1;
|
||||
POST = 2;
|
||||
HEAD = 3;
|
||||
PUT = 4;
|
||||
DELETE = 5;
|
||||
}
|
||||
optional RequestMethod method = 5;
|
||||
|
||||
optional int32 retry_count = 6 [default=0];
|
||||
|
||||
repeated group Header = 7 {
|
||||
required bytes key = 8;
|
||||
required bytes value = 9;
|
||||
}
|
||||
|
||||
optional int32 body_size = 10;
|
||||
optional bytes body = 11 [ctype=CORD];
|
||||
required int64 creation_time_usec = 12;
|
||||
|
||||
optional group CronTimetable = 13 {
|
||||
required bytes schedule = 14;
|
||||
required bytes timezone = 15;
|
||||
}
|
||||
|
||||
optional group RunLog = 16 {
|
||||
required int64 dispatched_usec = 17;
|
||||
required int64 lag_usec = 18;
|
||||
required int64 elapsed_usec = 19;
|
||||
optional int64 response_code = 20;
|
||||
optional string retry_reason = 27;
|
||||
}
|
||||
|
||||
optional bytes description = 21;
|
||||
optional TaskPayload payload = 22;
|
||||
optional TaskQueueRetryParameters retry_parameters = 23;
|
||||
optional int64 first_try_usec = 24;
|
||||
optional bytes tag = 25;
|
||||
optional int32 execution_count = 26 [default=0];
|
||||
}
|
||||
}
|
||||
|
||||
message TaskQueueFetchTaskRequest {
|
||||
optional bytes app_id = 1;
|
||||
required bytes queue_name = 2;
|
||||
required bytes task_name = 3;
|
||||
}
|
||||
|
||||
message TaskQueueFetchTaskResponse {
|
||||
required TaskQueueQueryTasksResponse task = 1;
|
||||
}
|
||||
|
||||
message TaskQueueUpdateStorageLimitRequest {
|
||||
required bytes app_id = 1;
|
||||
required int64 limit = 2;
|
||||
}
|
||||
|
||||
message TaskQueueUpdateStorageLimitResponse {
|
||||
required int64 new_limit = 1;
|
||||
}
|
||||
|
||||
message TaskQueueQueryAndOwnTasksRequest {
|
||||
required bytes queue_name = 1;
|
||||
required double lease_seconds = 2;
|
||||
required int64 max_tasks = 3;
|
||||
optional bool group_by_tag = 4 [default=false];
|
||||
optional bytes tag = 5;
|
||||
}
|
||||
|
||||
message TaskQueueQueryAndOwnTasksResponse {
|
||||
repeated group Task = 1 {
|
||||
required bytes task_name = 2;
|
||||
required int64 eta_usec = 3;
|
||||
optional int32 retry_count = 4 [default=0];
|
||||
optional bytes body = 5 [ctype=CORD];
|
||||
optional bytes tag = 6;
|
||||
}
|
||||
}
|
||||
|
||||
message TaskQueueModifyTaskLeaseRequest {
|
||||
required bytes queue_name = 1;
|
||||
required bytes task_name = 2;
|
||||
required int64 eta_usec = 3;
|
||||
required double lease_seconds = 4;
|
||||
}
|
||||
|
||||
message TaskQueueModifyTaskLeaseResponse {
|
||||
required int64 updated_eta_usec = 1;
|
||||
}
|
107
vendor/google.golang.org/appengine/internal/transaction.go
generated
vendored
Normal file
107
vendor/google.golang.org/appengine/internal/transaction.go
generated
vendored
Normal file
@@ -0,0 +1,107 @@
|
||||
// Copyright 2014 Google Inc. All rights reserved.
|
||||
// Use of this source code is governed by the Apache 2.0
|
||||
// license that can be found in the LICENSE file.
|
||||
|
||||
package internal
|
||||
|
||||
// This file implements hooks for applying datastore transactions.
|
||||
|
||||
import (
|
||||
"errors"
|
||||
"reflect"
|
||||
|
||||
"github.com/golang/protobuf/proto"
|
||||
netcontext "golang.org/x/net/context"
|
||||
|
||||
basepb "google.golang.org/appengine/internal/base"
|
||||
pb "google.golang.org/appengine/internal/datastore"
|
||||
)
|
||||
|
||||
var transactionSetters = make(map[reflect.Type]reflect.Value)
|
||||
|
||||
// RegisterTransactionSetter registers a function that sets transaction information
|
||||
// in a protocol buffer message. f should be a function with two arguments,
|
||||
// the first being a protocol buffer type, and the second being *datastore.Transaction.
|
||||
func RegisterTransactionSetter(f interface{}) {
|
||||
v := reflect.ValueOf(f)
|
||||
transactionSetters[v.Type().In(0)] = v
|
||||
}
|
||||
|
||||
// applyTransaction applies the transaction t to message pb
|
||||
// by using the relevant setter passed to RegisterTransactionSetter.
|
||||
func applyTransaction(pb proto.Message, t *pb.Transaction) {
|
||||
v := reflect.ValueOf(pb)
|
||||
if f, ok := transactionSetters[v.Type()]; ok {
|
||||
f.Call([]reflect.Value{v, reflect.ValueOf(t)})
|
||||
}
|
||||
}
|
||||
|
||||
var transactionKey = "used for *Transaction"
|
||||
|
||||
func transactionFromContext(ctx netcontext.Context) *transaction {
|
||||
t, _ := ctx.Value(&transactionKey).(*transaction)
|
||||
return t
|
||||
}
|
||||
|
||||
func withTransaction(ctx netcontext.Context, t *transaction) netcontext.Context {
|
||||
return netcontext.WithValue(ctx, &transactionKey, t)
|
||||
}
|
||||
|
||||
type transaction struct {
|
||||
transaction pb.Transaction
|
||||
finished bool
|
||||
}
|
||||
|
||||
var ErrConcurrentTransaction = errors.New("internal: concurrent transaction")
|
||||
|
||||
func RunTransactionOnce(c netcontext.Context, f func(netcontext.Context) error, xg bool) error {
|
||||
if transactionFromContext(c) != nil {
|
||||
return errors.New("nested transactions are not supported")
|
||||
}
|
||||
|
||||
// Begin the transaction.
|
||||
t := &transaction{}
|
||||
req := &pb.BeginTransactionRequest{
|
||||
App: proto.String(FullyQualifiedAppID(c)),
|
||||
}
|
||||
if xg {
|
||||
req.AllowMultipleEg = proto.Bool(true)
|
||||
}
|
||||
if err := Call(c, "datastore_v3", "BeginTransaction", req, &t.transaction); err != nil {
|
||||
return err
|
||||
}
|
||||
|
||||
// Call f, rolling back the transaction if f returns a non-nil error, or panics.
|
||||
// The panic is not recovered.
|
||||
defer func() {
|
||||
if t.finished {
|
||||
return
|
||||
}
|
||||
t.finished = true
|
||||
// Ignore the error return value, since we are already returning a non-nil
|
||||
// error (or we're panicking).
|
||||
Call(c, "datastore_v3", "Rollback", &t.transaction, &basepb.VoidProto{})
|
||||
}()
|
||||
if err := f(withTransaction(c, t)); err != nil {
|
||||
return err
|
||||
}
|
||||
t.finished = true
|
||||
|
||||
// Commit the transaction.
|
||||
res := &pb.CommitResponse{}
|
||||
err := Call(c, "datastore_v3", "Commit", &t.transaction, res)
|
||||
if ae, ok := err.(*APIError); ok {
|
||||
/* TODO: restore this conditional
|
||||
if appengine.IsDevAppServer() {
|
||||
*/
|
||||
// The Python Dev AppServer raises an ApplicationError with error code 2 (which is
|
||||
// Error.CONCURRENT_TRANSACTION) and message "Concurrency exception.".
|
||||
if ae.Code == int32(pb.Error_BAD_REQUEST) && ae.Detail == "ApplicationError: 2 Concurrency exception." {
|
||||
return ErrConcurrentTransaction
|
||||
}
|
||||
if ae.Code == int32(pb.Error_CONCURRENT_TRANSACTION) {
|
||||
return ErrConcurrentTransaction
|
||||
}
|
||||
}
|
||||
return err
|
||||
}
|
355
vendor/google.golang.org/appengine/internal/urlfetch/urlfetch_service.pb.go
generated
vendored
Normal file
355
vendor/google.golang.org/appengine/internal/urlfetch/urlfetch_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,355 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/urlfetch/urlfetch_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package urlfetch is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/urlfetch/urlfetch_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
URLFetchServiceError
|
||||
URLFetchRequest
|
||||
URLFetchResponse
|
||||
*/
|
||||
package urlfetch
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type URLFetchServiceError_ErrorCode int32
|
||||
|
||||
const (
|
||||
URLFetchServiceError_OK URLFetchServiceError_ErrorCode = 0
|
||||
URLFetchServiceError_INVALID_URL URLFetchServiceError_ErrorCode = 1
|
||||
URLFetchServiceError_FETCH_ERROR URLFetchServiceError_ErrorCode = 2
|
||||
URLFetchServiceError_UNSPECIFIED_ERROR URLFetchServiceError_ErrorCode = 3
|
||||
URLFetchServiceError_RESPONSE_TOO_LARGE URLFetchServiceError_ErrorCode = 4
|
||||
URLFetchServiceError_DEADLINE_EXCEEDED URLFetchServiceError_ErrorCode = 5
|
||||
URLFetchServiceError_SSL_CERTIFICATE_ERROR URLFetchServiceError_ErrorCode = 6
|
||||
URLFetchServiceError_DNS_ERROR URLFetchServiceError_ErrorCode = 7
|
||||
URLFetchServiceError_CLOSED URLFetchServiceError_ErrorCode = 8
|
||||
URLFetchServiceError_INTERNAL_TRANSIENT_ERROR URLFetchServiceError_ErrorCode = 9
|
||||
URLFetchServiceError_TOO_MANY_REDIRECTS URLFetchServiceError_ErrorCode = 10
|
||||
URLFetchServiceError_MALFORMED_REPLY URLFetchServiceError_ErrorCode = 11
|
||||
URLFetchServiceError_CONNECTION_ERROR URLFetchServiceError_ErrorCode = 12
|
||||
)
|
||||
|
||||
var URLFetchServiceError_ErrorCode_name = map[int32]string{
|
||||
0: "OK",
|
||||
1: "INVALID_URL",
|
||||
2: "FETCH_ERROR",
|
||||
3: "UNSPECIFIED_ERROR",
|
||||
4: "RESPONSE_TOO_LARGE",
|
||||
5: "DEADLINE_EXCEEDED",
|
||||
6: "SSL_CERTIFICATE_ERROR",
|
||||
7: "DNS_ERROR",
|
||||
8: "CLOSED",
|
||||
9: "INTERNAL_TRANSIENT_ERROR",
|
||||
10: "TOO_MANY_REDIRECTS",
|
||||
11: "MALFORMED_REPLY",
|
||||
12: "CONNECTION_ERROR",
|
||||
}
|
||||
var URLFetchServiceError_ErrorCode_value = map[string]int32{
|
||||
"OK": 0,
|
||||
"INVALID_URL": 1,
|
||||
"FETCH_ERROR": 2,
|
||||
"UNSPECIFIED_ERROR": 3,
|
||||
"RESPONSE_TOO_LARGE": 4,
|
||||
"DEADLINE_EXCEEDED": 5,
|
||||
"SSL_CERTIFICATE_ERROR": 6,
|
||||
"DNS_ERROR": 7,
|
||||
"CLOSED": 8,
|
||||
"INTERNAL_TRANSIENT_ERROR": 9,
|
||||
"TOO_MANY_REDIRECTS": 10,
|
||||
"MALFORMED_REPLY": 11,
|
||||
"CONNECTION_ERROR": 12,
|
||||
}
|
||||
|
||||
func (x URLFetchServiceError_ErrorCode) Enum() *URLFetchServiceError_ErrorCode {
|
||||
p := new(URLFetchServiceError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x URLFetchServiceError_ErrorCode) String() string {
|
||||
return proto.EnumName(URLFetchServiceError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *URLFetchServiceError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(URLFetchServiceError_ErrorCode_value, data, "URLFetchServiceError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = URLFetchServiceError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type URLFetchRequest_RequestMethod int32
|
||||
|
||||
const (
|
||||
URLFetchRequest_GET URLFetchRequest_RequestMethod = 1
|
||||
URLFetchRequest_POST URLFetchRequest_RequestMethod = 2
|
||||
URLFetchRequest_HEAD URLFetchRequest_RequestMethod = 3
|
||||
URLFetchRequest_PUT URLFetchRequest_RequestMethod = 4
|
||||
URLFetchRequest_DELETE URLFetchRequest_RequestMethod = 5
|
||||
URLFetchRequest_PATCH URLFetchRequest_RequestMethod = 6
|
||||
)
|
||||
|
||||
var URLFetchRequest_RequestMethod_name = map[int32]string{
|
||||
1: "GET",
|
||||
2: "POST",
|
||||
3: "HEAD",
|
||||
4: "PUT",
|
||||
5: "DELETE",
|
||||
6: "PATCH",
|
||||
}
|
||||
var URLFetchRequest_RequestMethod_value = map[string]int32{
|
||||
"GET": 1,
|
||||
"POST": 2,
|
||||
"HEAD": 3,
|
||||
"PUT": 4,
|
||||
"DELETE": 5,
|
||||
"PATCH": 6,
|
||||
}
|
||||
|
||||
func (x URLFetchRequest_RequestMethod) Enum() *URLFetchRequest_RequestMethod {
|
||||
p := new(URLFetchRequest_RequestMethod)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x URLFetchRequest_RequestMethod) String() string {
|
||||
return proto.EnumName(URLFetchRequest_RequestMethod_name, int32(x))
|
||||
}
|
||||
func (x *URLFetchRequest_RequestMethod) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(URLFetchRequest_RequestMethod_value, data, "URLFetchRequest_RequestMethod")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = URLFetchRequest_RequestMethod(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type URLFetchServiceError struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *URLFetchServiceError) Reset() { *m = URLFetchServiceError{} }
|
||||
func (m *URLFetchServiceError) String() string { return proto.CompactTextString(m) }
|
||||
func (*URLFetchServiceError) ProtoMessage() {}
|
||||
|
||||
type URLFetchRequest struct {
|
||||
Method *URLFetchRequest_RequestMethod `protobuf:"varint,1,req,name=Method,enum=appengine.URLFetchRequest_RequestMethod" json:"Method,omitempty"`
|
||||
Url *string `protobuf:"bytes,2,req,name=Url" json:"Url,omitempty"`
|
||||
Header []*URLFetchRequest_Header `protobuf:"group,3,rep,name=Header" json:"header,omitempty"`
|
||||
Payload []byte `protobuf:"bytes,6,opt,name=Payload" json:"Payload,omitempty"`
|
||||
FollowRedirects *bool `protobuf:"varint,7,opt,name=FollowRedirects,def=1" json:"FollowRedirects,omitempty"`
|
||||
Deadline *float64 `protobuf:"fixed64,8,opt,name=Deadline" json:"Deadline,omitempty"`
|
||||
MustValidateServerCertificate *bool `protobuf:"varint,9,opt,name=MustValidateServerCertificate,def=1" json:"MustValidateServerCertificate,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *URLFetchRequest) Reset() { *m = URLFetchRequest{} }
|
||||
func (m *URLFetchRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*URLFetchRequest) ProtoMessage() {}
|
||||
|
||||
const Default_URLFetchRequest_FollowRedirects bool = true
|
||||
const Default_URLFetchRequest_MustValidateServerCertificate bool = true
|
||||
|
||||
func (m *URLFetchRequest) GetMethod() URLFetchRequest_RequestMethod {
|
||||
if m != nil && m.Method != nil {
|
||||
return *m.Method
|
||||
}
|
||||
return URLFetchRequest_GET
|
||||
}
|
||||
|
||||
func (m *URLFetchRequest) GetUrl() string {
|
||||
if m != nil && m.Url != nil {
|
||||
return *m.Url
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *URLFetchRequest) GetHeader() []*URLFetchRequest_Header {
|
||||
if m != nil {
|
||||
return m.Header
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *URLFetchRequest) GetPayload() []byte {
|
||||
if m != nil {
|
||||
return m.Payload
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *URLFetchRequest) GetFollowRedirects() bool {
|
||||
if m != nil && m.FollowRedirects != nil {
|
||||
return *m.FollowRedirects
|
||||
}
|
||||
return Default_URLFetchRequest_FollowRedirects
|
||||
}
|
||||
|
||||
func (m *URLFetchRequest) GetDeadline() float64 {
|
||||
if m != nil && m.Deadline != nil {
|
||||
return *m.Deadline
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *URLFetchRequest) GetMustValidateServerCertificate() bool {
|
||||
if m != nil && m.MustValidateServerCertificate != nil {
|
||||
return *m.MustValidateServerCertificate
|
||||
}
|
||||
return Default_URLFetchRequest_MustValidateServerCertificate
|
||||
}
|
||||
|
||||
type URLFetchRequest_Header struct {
|
||||
Key *string `protobuf:"bytes,4,req,name=Key" json:"Key,omitempty"`
|
||||
Value *string `protobuf:"bytes,5,req,name=Value" json:"Value,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *URLFetchRequest_Header) Reset() { *m = URLFetchRequest_Header{} }
|
||||
func (m *URLFetchRequest_Header) String() string { return proto.CompactTextString(m) }
|
||||
func (*URLFetchRequest_Header) ProtoMessage() {}
|
||||
|
||||
func (m *URLFetchRequest_Header) GetKey() string {
|
||||
if m != nil && m.Key != nil {
|
||||
return *m.Key
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *URLFetchRequest_Header) GetValue() string {
|
||||
if m != nil && m.Value != nil {
|
||||
return *m.Value
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type URLFetchResponse struct {
|
||||
Content []byte `protobuf:"bytes,1,opt,name=Content" json:"Content,omitempty"`
|
||||
StatusCode *int32 `protobuf:"varint,2,req,name=StatusCode" json:"StatusCode,omitempty"`
|
||||
Header []*URLFetchResponse_Header `protobuf:"group,3,rep,name=Header" json:"header,omitempty"`
|
||||
ContentWasTruncated *bool `protobuf:"varint,6,opt,name=ContentWasTruncated,def=0" json:"ContentWasTruncated,omitempty"`
|
||||
ExternalBytesSent *int64 `protobuf:"varint,7,opt,name=ExternalBytesSent" json:"ExternalBytesSent,omitempty"`
|
||||
ExternalBytesReceived *int64 `protobuf:"varint,8,opt,name=ExternalBytesReceived" json:"ExternalBytesReceived,omitempty"`
|
||||
FinalUrl *string `protobuf:"bytes,9,opt,name=FinalUrl" json:"FinalUrl,omitempty"`
|
||||
ApiCpuMilliseconds *int64 `protobuf:"varint,10,opt,name=ApiCpuMilliseconds,def=0" json:"ApiCpuMilliseconds,omitempty"`
|
||||
ApiBytesSent *int64 `protobuf:"varint,11,opt,name=ApiBytesSent,def=0" json:"ApiBytesSent,omitempty"`
|
||||
ApiBytesReceived *int64 `protobuf:"varint,12,opt,name=ApiBytesReceived,def=0" json:"ApiBytesReceived,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *URLFetchResponse) Reset() { *m = URLFetchResponse{} }
|
||||
func (m *URLFetchResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*URLFetchResponse) ProtoMessage() {}
|
||||
|
||||
const Default_URLFetchResponse_ContentWasTruncated bool = false
|
||||
const Default_URLFetchResponse_ApiCpuMilliseconds int64 = 0
|
||||
const Default_URLFetchResponse_ApiBytesSent int64 = 0
|
||||
const Default_URLFetchResponse_ApiBytesReceived int64 = 0
|
||||
|
||||
func (m *URLFetchResponse) GetContent() []byte {
|
||||
if m != nil {
|
||||
return m.Content
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *URLFetchResponse) GetStatusCode() int32 {
|
||||
if m != nil && m.StatusCode != nil {
|
||||
return *m.StatusCode
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *URLFetchResponse) GetHeader() []*URLFetchResponse_Header {
|
||||
if m != nil {
|
||||
return m.Header
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *URLFetchResponse) GetContentWasTruncated() bool {
|
||||
if m != nil && m.ContentWasTruncated != nil {
|
||||
return *m.ContentWasTruncated
|
||||
}
|
||||
return Default_URLFetchResponse_ContentWasTruncated
|
||||
}
|
||||
|
||||
func (m *URLFetchResponse) GetExternalBytesSent() int64 {
|
||||
if m != nil && m.ExternalBytesSent != nil {
|
||||
return *m.ExternalBytesSent
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *URLFetchResponse) GetExternalBytesReceived() int64 {
|
||||
if m != nil && m.ExternalBytesReceived != nil {
|
||||
return *m.ExternalBytesReceived
|
||||
}
|
||||
return 0
|
||||
}
|
||||
|
||||
func (m *URLFetchResponse) GetFinalUrl() string {
|
||||
if m != nil && m.FinalUrl != nil {
|
||||
return *m.FinalUrl
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *URLFetchResponse) GetApiCpuMilliseconds() int64 {
|
||||
if m != nil && m.ApiCpuMilliseconds != nil {
|
||||
return *m.ApiCpuMilliseconds
|
||||
}
|
||||
return Default_URLFetchResponse_ApiCpuMilliseconds
|
||||
}
|
||||
|
||||
func (m *URLFetchResponse) GetApiBytesSent() int64 {
|
||||
if m != nil && m.ApiBytesSent != nil {
|
||||
return *m.ApiBytesSent
|
||||
}
|
||||
return Default_URLFetchResponse_ApiBytesSent
|
||||
}
|
||||
|
||||
func (m *URLFetchResponse) GetApiBytesReceived() int64 {
|
||||
if m != nil && m.ApiBytesReceived != nil {
|
||||
return *m.ApiBytesReceived
|
||||
}
|
||||
return Default_URLFetchResponse_ApiBytesReceived
|
||||
}
|
||||
|
||||
type URLFetchResponse_Header struct {
|
||||
Key *string `protobuf:"bytes,4,req,name=Key" json:"Key,omitempty"`
|
||||
Value *string `protobuf:"bytes,5,req,name=Value" json:"Value,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *URLFetchResponse_Header) Reset() { *m = URLFetchResponse_Header{} }
|
||||
func (m *URLFetchResponse_Header) String() string { return proto.CompactTextString(m) }
|
||||
func (*URLFetchResponse_Header) ProtoMessage() {}
|
||||
|
||||
func (m *URLFetchResponse_Header) GetKey() string {
|
||||
if m != nil && m.Key != nil {
|
||||
return *m.Key
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *URLFetchResponse_Header) GetValue() string {
|
||||
if m != nil && m.Value != nil {
|
||||
return *m.Value
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func init() {
|
||||
}
|
64
vendor/google.golang.org/appengine/internal/urlfetch/urlfetch_service.proto
generated
vendored
Normal file
64
vendor/google.golang.org/appengine/internal/urlfetch/urlfetch_service.proto
generated
vendored
Normal file
@@ -0,0 +1,64 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "urlfetch";
|
||||
|
||||
package appengine;
|
||||
|
||||
message URLFetchServiceError {
|
||||
enum ErrorCode {
|
||||
OK = 0;
|
||||
INVALID_URL = 1;
|
||||
FETCH_ERROR = 2;
|
||||
UNSPECIFIED_ERROR = 3;
|
||||
RESPONSE_TOO_LARGE = 4;
|
||||
DEADLINE_EXCEEDED = 5;
|
||||
SSL_CERTIFICATE_ERROR = 6;
|
||||
DNS_ERROR = 7;
|
||||
CLOSED = 8;
|
||||
INTERNAL_TRANSIENT_ERROR = 9;
|
||||
TOO_MANY_REDIRECTS = 10;
|
||||
MALFORMED_REPLY = 11;
|
||||
CONNECTION_ERROR = 12;
|
||||
}
|
||||
}
|
||||
|
||||
message URLFetchRequest {
|
||||
enum RequestMethod {
|
||||
GET = 1;
|
||||
POST = 2;
|
||||
HEAD = 3;
|
||||
PUT = 4;
|
||||
DELETE = 5;
|
||||
PATCH = 6;
|
||||
}
|
||||
required RequestMethod Method = 1;
|
||||
required string Url = 2;
|
||||
repeated group Header = 3 {
|
||||
required string Key = 4;
|
||||
required string Value = 5;
|
||||
}
|
||||
optional bytes Payload = 6 [ctype=CORD];
|
||||
|
||||
optional bool FollowRedirects = 7 [default=true];
|
||||
|
||||
optional double Deadline = 8;
|
||||
|
||||
optional bool MustValidateServerCertificate = 9 [default=true];
|
||||
}
|
||||
|
||||
message URLFetchResponse {
|
||||
optional bytes Content = 1;
|
||||
required int32 StatusCode = 2;
|
||||
repeated group Header = 3 {
|
||||
required string Key = 4;
|
||||
required string Value = 5;
|
||||
}
|
||||
optional bool ContentWasTruncated = 6 [default=false];
|
||||
optional int64 ExternalBytesSent = 7;
|
||||
optional int64 ExternalBytesReceived = 8;
|
||||
|
||||
optional string FinalUrl = 9;
|
||||
|
||||
optional int64 ApiCpuMilliseconds = 10 [default=0];
|
||||
optional int64 ApiBytesSent = 11 [default=0];
|
||||
optional int64 ApiBytesReceived = 12 [default=0];
|
||||
}
|
289
vendor/google.golang.org/appengine/internal/user/user_service.pb.go
generated
vendored
Normal file
289
vendor/google.golang.org/appengine/internal/user/user_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,289 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/user/user_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package user is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/user/user_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
UserServiceError
|
||||
CreateLoginURLRequest
|
||||
CreateLoginURLResponse
|
||||
CreateLogoutURLRequest
|
||||
CreateLogoutURLResponse
|
||||
GetOAuthUserRequest
|
||||
GetOAuthUserResponse
|
||||
CheckOAuthSignatureRequest
|
||||
CheckOAuthSignatureResponse
|
||||
*/
|
||||
package user
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type UserServiceError_ErrorCode int32
|
||||
|
||||
const (
|
||||
UserServiceError_OK UserServiceError_ErrorCode = 0
|
||||
UserServiceError_REDIRECT_URL_TOO_LONG UserServiceError_ErrorCode = 1
|
||||
UserServiceError_NOT_ALLOWED UserServiceError_ErrorCode = 2
|
||||
UserServiceError_OAUTH_INVALID_TOKEN UserServiceError_ErrorCode = 3
|
||||
UserServiceError_OAUTH_INVALID_REQUEST UserServiceError_ErrorCode = 4
|
||||
UserServiceError_OAUTH_ERROR UserServiceError_ErrorCode = 5
|
||||
)
|
||||
|
||||
var UserServiceError_ErrorCode_name = map[int32]string{
|
||||
0: "OK",
|
||||
1: "REDIRECT_URL_TOO_LONG",
|
||||
2: "NOT_ALLOWED",
|
||||
3: "OAUTH_INVALID_TOKEN",
|
||||
4: "OAUTH_INVALID_REQUEST",
|
||||
5: "OAUTH_ERROR",
|
||||
}
|
||||
var UserServiceError_ErrorCode_value = map[string]int32{
|
||||
"OK": 0,
|
||||
"REDIRECT_URL_TOO_LONG": 1,
|
||||
"NOT_ALLOWED": 2,
|
||||
"OAUTH_INVALID_TOKEN": 3,
|
||||
"OAUTH_INVALID_REQUEST": 4,
|
||||
"OAUTH_ERROR": 5,
|
||||
}
|
||||
|
||||
func (x UserServiceError_ErrorCode) Enum() *UserServiceError_ErrorCode {
|
||||
p := new(UserServiceError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x UserServiceError_ErrorCode) String() string {
|
||||
return proto.EnumName(UserServiceError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *UserServiceError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(UserServiceError_ErrorCode_value, data, "UserServiceError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = UserServiceError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type UserServiceError struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *UserServiceError) Reset() { *m = UserServiceError{} }
|
||||
func (m *UserServiceError) String() string { return proto.CompactTextString(m) }
|
||||
func (*UserServiceError) ProtoMessage() {}
|
||||
|
||||
type CreateLoginURLRequest struct {
|
||||
DestinationUrl *string `protobuf:"bytes,1,req,name=destination_url" json:"destination_url,omitempty"`
|
||||
AuthDomain *string `protobuf:"bytes,2,opt,name=auth_domain" json:"auth_domain,omitempty"`
|
||||
FederatedIdentity *string `protobuf:"bytes,3,opt,name=federated_identity,def=" json:"federated_identity,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CreateLoginURLRequest) Reset() { *m = CreateLoginURLRequest{} }
|
||||
func (m *CreateLoginURLRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*CreateLoginURLRequest) ProtoMessage() {}
|
||||
|
||||
func (m *CreateLoginURLRequest) GetDestinationUrl() string {
|
||||
if m != nil && m.DestinationUrl != nil {
|
||||
return *m.DestinationUrl
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *CreateLoginURLRequest) GetAuthDomain() string {
|
||||
if m != nil && m.AuthDomain != nil {
|
||||
return *m.AuthDomain
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *CreateLoginURLRequest) GetFederatedIdentity() string {
|
||||
if m != nil && m.FederatedIdentity != nil {
|
||||
return *m.FederatedIdentity
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type CreateLoginURLResponse struct {
|
||||
LoginUrl *string `protobuf:"bytes,1,req,name=login_url" json:"login_url,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CreateLoginURLResponse) Reset() { *m = CreateLoginURLResponse{} }
|
||||
func (m *CreateLoginURLResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*CreateLoginURLResponse) ProtoMessage() {}
|
||||
|
||||
func (m *CreateLoginURLResponse) GetLoginUrl() string {
|
||||
if m != nil && m.LoginUrl != nil {
|
||||
return *m.LoginUrl
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type CreateLogoutURLRequest struct {
|
||||
DestinationUrl *string `protobuf:"bytes,1,req,name=destination_url" json:"destination_url,omitempty"`
|
||||
AuthDomain *string `protobuf:"bytes,2,opt,name=auth_domain" json:"auth_domain,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CreateLogoutURLRequest) Reset() { *m = CreateLogoutURLRequest{} }
|
||||
func (m *CreateLogoutURLRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*CreateLogoutURLRequest) ProtoMessage() {}
|
||||
|
||||
func (m *CreateLogoutURLRequest) GetDestinationUrl() string {
|
||||
if m != nil && m.DestinationUrl != nil {
|
||||
return *m.DestinationUrl
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *CreateLogoutURLRequest) GetAuthDomain() string {
|
||||
if m != nil && m.AuthDomain != nil {
|
||||
return *m.AuthDomain
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type CreateLogoutURLResponse struct {
|
||||
LogoutUrl *string `protobuf:"bytes,1,req,name=logout_url" json:"logout_url,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CreateLogoutURLResponse) Reset() { *m = CreateLogoutURLResponse{} }
|
||||
func (m *CreateLogoutURLResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*CreateLogoutURLResponse) ProtoMessage() {}
|
||||
|
||||
func (m *CreateLogoutURLResponse) GetLogoutUrl() string {
|
||||
if m != nil && m.LogoutUrl != nil {
|
||||
return *m.LogoutUrl
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type GetOAuthUserRequest struct {
|
||||
Scope *string `protobuf:"bytes,1,opt,name=scope" json:"scope,omitempty"`
|
||||
Scopes []string `protobuf:"bytes,2,rep,name=scopes" json:"scopes,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetOAuthUserRequest) Reset() { *m = GetOAuthUserRequest{} }
|
||||
func (m *GetOAuthUserRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetOAuthUserRequest) ProtoMessage() {}
|
||||
|
||||
func (m *GetOAuthUserRequest) GetScope() string {
|
||||
if m != nil && m.Scope != nil {
|
||||
return *m.Scope
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *GetOAuthUserRequest) GetScopes() []string {
|
||||
if m != nil {
|
||||
return m.Scopes
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type GetOAuthUserResponse struct {
|
||||
Email *string `protobuf:"bytes,1,req,name=email" json:"email,omitempty"`
|
||||
UserId *string `protobuf:"bytes,2,req,name=user_id" json:"user_id,omitempty"`
|
||||
AuthDomain *string `protobuf:"bytes,3,req,name=auth_domain" json:"auth_domain,omitempty"`
|
||||
UserOrganization *string `protobuf:"bytes,4,opt,name=user_organization,def=" json:"user_organization,omitempty"`
|
||||
IsAdmin *bool `protobuf:"varint,5,opt,name=is_admin,def=0" json:"is_admin,omitempty"`
|
||||
ClientId *string `protobuf:"bytes,6,opt,name=client_id,def=" json:"client_id,omitempty"`
|
||||
Scopes []string `protobuf:"bytes,7,rep,name=scopes" json:"scopes,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *GetOAuthUserResponse) Reset() { *m = GetOAuthUserResponse{} }
|
||||
func (m *GetOAuthUserResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*GetOAuthUserResponse) ProtoMessage() {}
|
||||
|
||||
const Default_GetOAuthUserResponse_IsAdmin bool = false
|
||||
|
||||
func (m *GetOAuthUserResponse) GetEmail() string {
|
||||
if m != nil && m.Email != nil {
|
||||
return *m.Email
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *GetOAuthUserResponse) GetUserId() string {
|
||||
if m != nil && m.UserId != nil {
|
||||
return *m.UserId
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *GetOAuthUserResponse) GetAuthDomain() string {
|
||||
if m != nil && m.AuthDomain != nil {
|
||||
return *m.AuthDomain
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *GetOAuthUserResponse) GetUserOrganization() string {
|
||||
if m != nil && m.UserOrganization != nil {
|
||||
return *m.UserOrganization
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *GetOAuthUserResponse) GetIsAdmin() bool {
|
||||
if m != nil && m.IsAdmin != nil {
|
||||
return *m.IsAdmin
|
||||
}
|
||||
return Default_GetOAuthUserResponse_IsAdmin
|
||||
}
|
||||
|
||||
func (m *GetOAuthUserResponse) GetClientId() string {
|
||||
if m != nil && m.ClientId != nil {
|
||||
return *m.ClientId
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *GetOAuthUserResponse) GetScopes() []string {
|
||||
if m != nil {
|
||||
return m.Scopes
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type CheckOAuthSignatureRequest struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CheckOAuthSignatureRequest) Reset() { *m = CheckOAuthSignatureRequest{} }
|
||||
func (m *CheckOAuthSignatureRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*CheckOAuthSignatureRequest) ProtoMessage() {}
|
||||
|
||||
type CheckOAuthSignatureResponse struct {
|
||||
OauthConsumerKey *string `protobuf:"bytes,1,req,name=oauth_consumer_key" json:"oauth_consumer_key,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *CheckOAuthSignatureResponse) Reset() { *m = CheckOAuthSignatureResponse{} }
|
||||
func (m *CheckOAuthSignatureResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*CheckOAuthSignatureResponse) ProtoMessage() {}
|
||||
|
||||
func (m *CheckOAuthSignatureResponse) GetOauthConsumerKey() string {
|
||||
if m != nil && m.OauthConsumerKey != nil {
|
||||
return *m.OauthConsumerKey
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func init() {
|
||||
}
|
58
vendor/google.golang.org/appengine/internal/user/user_service.proto
generated
vendored
Normal file
58
vendor/google.golang.org/appengine/internal/user/user_service.proto
generated
vendored
Normal file
@@ -0,0 +1,58 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "user";
|
||||
|
||||
package appengine;
|
||||
|
||||
message UserServiceError {
|
||||
enum ErrorCode {
|
||||
OK = 0;
|
||||
REDIRECT_URL_TOO_LONG = 1;
|
||||
NOT_ALLOWED = 2;
|
||||
OAUTH_INVALID_TOKEN = 3;
|
||||
OAUTH_INVALID_REQUEST = 4;
|
||||
OAUTH_ERROR = 5;
|
||||
}
|
||||
}
|
||||
|
||||
message CreateLoginURLRequest {
|
||||
required string destination_url = 1;
|
||||
optional string auth_domain = 2;
|
||||
optional string federated_identity = 3 [default = ""];
|
||||
}
|
||||
|
||||
message CreateLoginURLResponse {
|
||||
required string login_url = 1;
|
||||
}
|
||||
|
||||
message CreateLogoutURLRequest {
|
||||
required string destination_url = 1;
|
||||
optional string auth_domain = 2;
|
||||
}
|
||||
|
||||
message CreateLogoutURLResponse {
|
||||
required string logout_url = 1;
|
||||
}
|
||||
|
||||
message GetOAuthUserRequest {
|
||||
optional string scope = 1;
|
||||
|
||||
repeated string scopes = 2;
|
||||
}
|
||||
|
||||
message GetOAuthUserResponse {
|
||||
required string email = 1;
|
||||
required string user_id = 2;
|
||||
required string auth_domain = 3;
|
||||
optional string user_organization = 4 [default = ""];
|
||||
optional bool is_admin = 5 [default = false];
|
||||
optional string client_id = 6 [default = ""];
|
||||
|
||||
repeated string scopes = 7;
|
||||
}
|
||||
|
||||
message CheckOAuthSignatureRequest {
|
||||
}
|
||||
|
||||
message CheckOAuthSignatureResponse {
|
||||
required string oauth_consumer_key = 1;
|
||||
}
|
427
vendor/google.golang.org/appengine/internal/xmpp/xmpp_service.pb.go
generated
vendored
Normal file
427
vendor/google.golang.org/appengine/internal/xmpp/xmpp_service.pb.go
generated
vendored
Normal file
@@ -0,0 +1,427 @@
|
||||
// Code generated by protoc-gen-go.
|
||||
// source: google.golang.org/appengine/internal/xmpp/xmpp_service.proto
|
||||
// DO NOT EDIT!
|
||||
|
||||
/*
|
||||
Package xmpp is a generated protocol buffer package.
|
||||
|
||||
It is generated from these files:
|
||||
google.golang.org/appengine/internal/xmpp/xmpp_service.proto
|
||||
|
||||
It has these top-level messages:
|
||||
XmppServiceError
|
||||
PresenceRequest
|
||||
PresenceResponse
|
||||
BulkPresenceRequest
|
||||
BulkPresenceResponse
|
||||
XmppMessageRequest
|
||||
XmppMessageResponse
|
||||
XmppSendPresenceRequest
|
||||
XmppSendPresenceResponse
|
||||
XmppInviteRequest
|
||||
XmppInviteResponse
|
||||
*/
|
||||
package xmpp
|
||||
|
||||
import proto "github.com/golang/protobuf/proto"
|
||||
import fmt "fmt"
|
||||
import math "math"
|
||||
|
||||
// Reference imports to suppress errors if they are not otherwise used.
|
||||
var _ = proto.Marshal
|
||||
var _ = fmt.Errorf
|
||||
var _ = math.Inf
|
||||
|
||||
type XmppServiceError_ErrorCode int32
|
||||
|
||||
const (
|
||||
XmppServiceError_UNSPECIFIED_ERROR XmppServiceError_ErrorCode = 1
|
||||
XmppServiceError_INVALID_JID XmppServiceError_ErrorCode = 2
|
||||
XmppServiceError_NO_BODY XmppServiceError_ErrorCode = 3
|
||||
XmppServiceError_INVALID_XML XmppServiceError_ErrorCode = 4
|
||||
XmppServiceError_INVALID_TYPE XmppServiceError_ErrorCode = 5
|
||||
XmppServiceError_INVALID_SHOW XmppServiceError_ErrorCode = 6
|
||||
XmppServiceError_EXCEEDED_MAX_SIZE XmppServiceError_ErrorCode = 7
|
||||
XmppServiceError_APPID_ALIAS_REQUIRED XmppServiceError_ErrorCode = 8
|
||||
XmppServiceError_NONDEFAULT_MODULE XmppServiceError_ErrorCode = 9
|
||||
)
|
||||
|
||||
var XmppServiceError_ErrorCode_name = map[int32]string{
|
||||
1: "UNSPECIFIED_ERROR",
|
||||
2: "INVALID_JID",
|
||||
3: "NO_BODY",
|
||||
4: "INVALID_XML",
|
||||
5: "INVALID_TYPE",
|
||||
6: "INVALID_SHOW",
|
||||
7: "EXCEEDED_MAX_SIZE",
|
||||
8: "APPID_ALIAS_REQUIRED",
|
||||
9: "NONDEFAULT_MODULE",
|
||||
}
|
||||
var XmppServiceError_ErrorCode_value = map[string]int32{
|
||||
"UNSPECIFIED_ERROR": 1,
|
||||
"INVALID_JID": 2,
|
||||
"NO_BODY": 3,
|
||||
"INVALID_XML": 4,
|
||||
"INVALID_TYPE": 5,
|
||||
"INVALID_SHOW": 6,
|
||||
"EXCEEDED_MAX_SIZE": 7,
|
||||
"APPID_ALIAS_REQUIRED": 8,
|
||||
"NONDEFAULT_MODULE": 9,
|
||||
}
|
||||
|
||||
func (x XmppServiceError_ErrorCode) Enum() *XmppServiceError_ErrorCode {
|
||||
p := new(XmppServiceError_ErrorCode)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x XmppServiceError_ErrorCode) String() string {
|
||||
return proto.EnumName(XmppServiceError_ErrorCode_name, int32(x))
|
||||
}
|
||||
func (x *XmppServiceError_ErrorCode) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(XmppServiceError_ErrorCode_value, data, "XmppServiceError_ErrorCode")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = XmppServiceError_ErrorCode(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type PresenceResponse_SHOW int32
|
||||
|
||||
const (
|
||||
PresenceResponse_NORMAL PresenceResponse_SHOW = 0
|
||||
PresenceResponse_AWAY PresenceResponse_SHOW = 1
|
||||
PresenceResponse_DO_NOT_DISTURB PresenceResponse_SHOW = 2
|
||||
PresenceResponse_CHAT PresenceResponse_SHOW = 3
|
||||
PresenceResponse_EXTENDED_AWAY PresenceResponse_SHOW = 4
|
||||
)
|
||||
|
||||
var PresenceResponse_SHOW_name = map[int32]string{
|
||||
0: "NORMAL",
|
||||
1: "AWAY",
|
||||
2: "DO_NOT_DISTURB",
|
||||
3: "CHAT",
|
||||
4: "EXTENDED_AWAY",
|
||||
}
|
||||
var PresenceResponse_SHOW_value = map[string]int32{
|
||||
"NORMAL": 0,
|
||||
"AWAY": 1,
|
||||
"DO_NOT_DISTURB": 2,
|
||||
"CHAT": 3,
|
||||
"EXTENDED_AWAY": 4,
|
||||
}
|
||||
|
||||
func (x PresenceResponse_SHOW) Enum() *PresenceResponse_SHOW {
|
||||
p := new(PresenceResponse_SHOW)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x PresenceResponse_SHOW) String() string {
|
||||
return proto.EnumName(PresenceResponse_SHOW_name, int32(x))
|
||||
}
|
||||
func (x *PresenceResponse_SHOW) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(PresenceResponse_SHOW_value, data, "PresenceResponse_SHOW")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = PresenceResponse_SHOW(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type XmppMessageResponse_XmppMessageStatus int32
|
||||
|
||||
const (
|
||||
XmppMessageResponse_NO_ERROR XmppMessageResponse_XmppMessageStatus = 0
|
||||
XmppMessageResponse_INVALID_JID XmppMessageResponse_XmppMessageStatus = 1
|
||||
XmppMessageResponse_OTHER_ERROR XmppMessageResponse_XmppMessageStatus = 2
|
||||
)
|
||||
|
||||
var XmppMessageResponse_XmppMessageStatus_name = map[int32]string{
|
||||
0: "NO_ERROR",
|
||||
1: "INVALID_JID",
|
||||
2: "OTHER_ERROR",
|
||||
}
|
||||
var XmppMessageResponse_XmppMessageStatus_value = map[string]int32{
|
||||
"NO_ERROR": 0,
|
||||
"INVALID_JID": 1,
|
||||
"OTHER_ERROR": 2,
|
||||
}
|
||||
|
||||
func (x XmppMessageResponse_XmppMessageStatus) Enum() *XmppMessageResponse_XmppMessageStatus {
|
||||
p := new(XmppMessageResponse_XmppMessageStatus)
|
||||
*p = x
|
||||
return p
|
||||
}
|
||||
func (x XmppMessageResponse_XmppMessageStatus) String() string {
|
||||
return proto.EnumName(XmppMessageResponse_XmppMessageStatus_name, int32(x))
|
||||
}
|
||||
func (x *XmppMessageResponse_XmppMessageStatus) UnmarshalJSON(data []byte) error {
|
||||
value, err := proto.UnmarshalJSONEnum(XmppMessageResponse_XmppMessageStatus_value, data, "XmppMessageResponse_XmppMessageStatus")
|
||||
if err != nil {
|
||||
return err
|
||||
}
|
||||
*x = XmppMessageResponse_XmppMessageStatus(value)
|
||||
return nil
|
||||
}
|
||||
|
||||
type XmppServiceError struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *XmppServiceError) Reset() { *m = XmppServiceError{} }
|
||||
func (m *XmppServiceError) String() string { return proto.CompactTextString(m) }
|
||||
func (*XmppServiceError) ProtoMessage() {}
|
||||
|
||||
type PresenceRequest struct {
|
||||
Jid *string `protobuf:"bytes,1,req,name=jid" json:"jid,omitempty"`
|
||||
FromJid *string `protobuf:"bytes,2,opt,name=from_jid" json:"from_jid,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *PresenceRequest) Reset() { *m = PresenceRequest{} }
|
||||
func (m *PresenceRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*PresenceRequest) ProtoMessage() {}
|
||||
|
||||
func (m *PresenceRequest) GetJid() string {
|
||||
if m != nil && m.Jid != nil {
|
||||
return *m.Jid
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *PresenceRequest) GetFromJid() string {
|
||||
if m != nil && m.FromJid != nil {
|
||||
return *m.FromJid
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type PresenceResponse struct {
|
||||
IsAvailable *bool `protobuf:"varint,1,req,name=is_available" json:"is_available,omitempty"`
|
||||
Presence *PresenceResponse_SHOW `protobuf:"varint,2,opt,name=presence,enum=appengine.PresenceResponse_SHOW" json:"presence,omitempty"`
|
||||
Valid *bool `protobuf:"varint,3,opt,name=valid" json:"valid,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *PresenceResponse) Reset() { *m = PresenceResponse{} }
|
||||
func (m *PresenceResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*PresenceResponse) ProtoMessage() {}
|
||||
|
||||
func (m *PresenceResponse) GetIsAvailable() bool {
|
||||
if m != nil && m.IsAvailable != nil {
|
||||
return *m.IsAvailable
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
func (m *PresenceResponse) GetPresence() PresenceResponse_SHOW {
|
||||
if m != nil && m.Presence != nil {
|
||||
return *m.Presence
|
||||
}
|
||||
return PresenceResponse_NORMAL
|
||||
}
|
||||
|
||||
func (m *PresenceResponse) GetValid() bool {
|
||||
if m != nil && m.Valid != nil {
|
||||
return *m.Valid
|
||||
}
|
||||
return false
|
||||
}
|
||||
|
||||
type BulkPresenceRequest struct {
|
||||
Jid []string `protobuf:"bytes,1,rep,name=jid" json:"jid,omitempty"`
|
||||
FromJid *string `protobuf:"bytes,2,opt,name=from_jid" json:"from_jid,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *BulkPresenceRequest) Reset() { *m = BulkPresenceRequest{} }
|
||||
func (m *BulkPresenceRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*BulkPresenceRequest) ProtoMessage() {}
|
||||
|
||||
func (m *BulkPresenceRequest) GetJid() []string {
|
||||
if m != nil {
|
||||
return m.Jid
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *BulkPresenceRequest) GetFromJid() string {
|
||||
if m != nil && m.FromJid != nil {
|
||||
return *m.FromJid
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type BulkPresenceResponse struct {
|
||||
PresenceResponse []*PresenceResponse `protobuf:"bytes,1,rep,name=presence_response" json:"presence_response,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *BulkPresenceResponse) Reset() { *m = BulkPresenceResponse{} }
|
||||
func (m *BulkPresenceResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*BulkPresenceResponse) ProtoMessage() {}
|
||||
|
||||
func (m *BulkPresenceResponse) GetPresenceResponse() []*PresenceResponse {
|
||||
if m != nil {
|
||||
return m.PresenceResponse
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type XmppMessageRequest struct {
|
||||
Jid []string `protobuf:"bytes,1,rep,name=jid" json:"jid,omitempty"`
|
||||
Body *string `protobuf:"bytes,2,req,name=body" json:"body,omitempty"`
|
||||
RawXml *bool `protobuf:"varint,3,opt,name=raw_xml,def=0" json:"raw_xml,omitempty"`
|
||||
Type *string `protobuf:"bytes,4,opt,name=type,def=chat" json:"type,omitempty"`
|
||||
FromJid *string `protobuf:"bytes,5,opt,name=from_jid" json:"from_jid,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *XmppMessageRequest) Reset() { *m = XmppMessageRequest{} }
|
||||
func (m *XmppMessageRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*XmppMessageRequest) ProtoMessage() {}
|
||||
|
||||
const Default_XmppMessageRequest_RawXml bool = false
|
||||
const Default_XmppMessageRequest_Type string = "chat"
|
||||
|
||||
func (m *XmppMessageRequest) GetJid() []string {
|
||||
if m != nil {
|
||||
return m.Jid
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
func (m *XmppMessageRequest) GetBody() string {
|
||||
if m != nil && m.Body != nil {
|
||||
return *m.Body
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *XmppMessageRequest) GetRawXml() bool {
|
||||
if m != nil && m.RawXml != nil {
|
||||
return *m.RawXml
|
||||
}
|
||||
return Default_XmppMessageRequest_RawXml
|
||||
}
|
||||
|
||||
func (m *XmppMessageRequest) GetType() string {
|
||||
if m != nil && m.Type != nil {
|
||||
return *m.Type
|
||||
}
|
||||
return Default_XmppMessageRequest_Type
|
||||
}
|
||||
|
||||
func (m *XmppMessageRequest) GetFromJid() string {
|
||||
if m != nil && m.FromJid != nil {
|
||||
return *m.FromJid
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type XmppMessageResponse struct {
|
||||
Status []XmppMessageResponse_XmppMessageStatus `protobuf:"varint,1,rep,name=status,enum=appengine.XmppMessageResponse_XmppMessageStatus" json:"status,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *XmppMessageResponse) Reset() { *m = XmppMessageResponse{} }
|
||||
func (m *XmppMessageResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*XmppMessageResponse) ProtoMessage() {}
|
||||
|
||||
func (m *XmppMessageResponse) GetStatus() []XmppMessageResponse_XmppMessageStatus {
|
||||
if m != nil {
|
||||
return m.Status
|
||||
}
|
||||
return nil
|
||||
}
|
||||
|
||||
type XmppSendPresenceRequest struct {
|
||||
Jid *string `protobuf:"bytes,1,req,name=jid" json:"jid,omitempty"`
|
||||
Type *string `protobuf:"bytes,2,opt,name=type" json:"type,omitempty"`
|
||||
Show *string `protobuf:"bytes,3,opt,name=show" json:"show,omitempty"`
|
||||
Status *string `protobuf:"bytes,4,opt,name=status" json:"status,omitempty"`
|
||||
FromJid *string `protobuf:"bytes,5,opt,name=from_jid" json:"from_jid,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *XmppSendPresenceRequest) Reset() { *m = XmppSendPresenceRequest{} }
|
||||
func (m *XmppSendPresenceRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*XmppSendPresenceRequest) ProtoMessage() {}
|
||||
|
||||
func (m *XmppSendPresenceRequest) GetJid() string {
|
||||
if m != nil && m.Jid != nil {
|
||||
return *m.Jid
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *XmppSendPresenceRequest) GetType() string {
|
||||
if m != nil && m.Type != nil {
|
||||
return *m.Type
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *XmppSendPresenceRequest) GetShow() string {
|
||||
if m != nil && m.Show != nil {
|
||||
return *m.Show
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *XmppSendPresenceRequest) GetStatus() string {
|
||||
if m != nil && m.Status != nil {
|
||||
return *m.Status
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *XmppSendPresenceRequest) GetFromJid() string {
|
||||
if m != nil && m.FromJid != nil {
|
||||
return *m.FromJid
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type XmppSendPresenceResponse struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *XmppSendPresenceResponse) Reset() { *m = XmppSendPresenceResponse{} }
|
||||
func (m *XmppSendPresenceResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*XmppSendPresenceResponse) ProtoMessage() {}
|
||||
|
||||
type XmppInviteRequest struct {
|
||||
Jid *string `protobuf:"bytes,1,req,name=jid" json:"jid,omitempty"`
|
||||
FromJid *string `protobuf:"bytes,2,opt,name=from_jid" json:"from_jid,omitempty"`
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *XmppInviteRequest) Reset() { *m = XmppInviteRequest{} }
|
||||
func (m *XmppInviteRequest) String() string { return proto.CompactTextString(m) }
|
||||
func (*XmppInviteRequest) ProtoMessage() {}
|
||||
|
||||
func (m *XmppInviteRequest) GetJid() string {
|
||||
if m != nil && m.Jid != nil {
|
||||
return *m.Jid
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
func (m *XmppInviteRequest) GetFromJid() string {
|
||||
if m != nil && m.FromJid != nil {
|
||||
return *m.FromJid
|
||||
}
|
||||
return ""
|
||||
}
|
||||
|
||||
type XmppInviteResponse struct {
|
||||
XXX_unrecognized []byte `json:"-"`
|
||||
}
|
||||
|
||||
func (m *XmppInviteResponse) Reset() { *m = XmppInviteResponse{} }
|
||||
func (m *XmppInviteResponse) String() string { return proto.CompactTextString(m) }
|
||||
func (*XmppInviteResponse) ProtoMessage() {}
|
||||
|
||||
func init() {
|
||||
}
|
83
vendor/google.golang.org/appengine/internal/xmpp/xmpp_service.proto
generated
vendored
Normal file
83
vendor/google.golang.org/appengine/internal/xmpp/xmpp_service.proto
generated
vendored
Normal file
@@ -0,0 +1,83 @@
|
||||
syntax = "proto2";
|
||||
option go_package = "xmpp";
|
||||
|
||||
package appengine;
|
||||
|
||||
message XmppServiceError {
|
||||
enum ErrorCode {
|
||||
UNSPECIFIED_ERROR = 1;
|
||||
INVALID_JID = 2;
|
||||
NO_BODY = 3;
|
||||
INVALID_XML = 4;
|
||||
INVALID_TYPE = 5;
|
||||
INVALID_SHOW = 6;
|
||||
EXCEEDED_MAX_SIZE = 7;
|
||||
APPID_ALIAS_REQUIRED = 8;
|
||||
NONDEFAULT_MODULE = 9;
|
||||
}
|
||||
}
|
||||
|
||||
message PresenceRequest {
|
||||
required string jid = 1;
|
||||
optional string from_jid = 2;
|
||||
}
|
||||
|
||||
message PresenceResponse {
|
||||
enum SHOW {
|
||||
NORMAL = 0;
|
||||
AWAY = 1;
|
||||
DO_NOT_DISTURB = 2;
|
||||
CHAT = 3;
|
||||
EXTENDED_AWAY = 4;
|
||||
}
|
||||
|
||||
required bool is_available = 1;
|
||||
optional SHOW presence = 2;
|
||||
optional bool valid = 3;
|
||||
}
|
||||
|
||||
message BulkPresenceRequest {
|
||||
repeated string jid = 1;
|
||||
optional string from_jid = 2;
|
||||
}
|
||||
|
||||
message BulkPresenceResponse {
|
||||
repeated PresenceResponse presence_response = 1;
|
||||
}
|
||||
|
||||
message XmppMessageRequest {
|
||||
repeated string jid = 1;
|
||||
required string body = 2;
|
||||
optional bool raw_xml = 3 [ default = false ];
|
||||
optional string type = 4 [ default = "chat" ];
|
||||
optional string from_jid = 5;
|
||||
}
|
||||
|
||||
message XmppMessageResponse {
|
||||
enum XmppMessageStatus {
|
||||
NO_ERROR = 0;
|
||||
INVALID_JID = 1;
|
||||
OTHER_ERROR = 2;
|
||||
}
|
||||
|
||||
repeated XmppMessageStatus status = 1;
|
||||
}
|
||||
|
||||
message XmppSendPresenceRequest {
|
||||
required string jid = 1;
|
||||
optional string type = 2;
|
||||
optional string show = 3;
|
||||
optional string status = 4;
|
||||
optional string from_jid = 5;
|
||||
}
|
||||
|
||||
message XmppSendPresenceResponse {
|
||||
}
|
||||
|
||||
message XmppInviteRequest {
|
||||
required string jid = 1;
|
||||
optional string from_jid = 2;
|
||||
}
|
||||
|
||||
message XmppInviteResponse {
|
||||
}
|
Reference in New Issue
Block a user