Vehicle-Anti-Theft-Face-Rec.../venv/Lib/site-packages/gcloud/pubsub/test_connection.py

749 lines
28 KiB
Python

# Copyright 2015 Google Inc. All rights reserved.
#
# Licensed under the Apache License, Version 2.0 (the "License");
# you may not use this file except in compliance with the License.
# You may obtain a copy of the License at
#
# http://www.apache.org/licenses/LICENSE-2.0
#
# Unless required by applicable law or agreed to in writing, software
# distributed under the License is distributed on an "AS IS" BASIS,
# WITHOUT WARRANTIES OR CONDITIONS OF ANY KIND, either express or implied.
# See the License for the specific language governing permissions and
# limitations under the License.
import unittest2
class _Base(unittest2.TestCase):
PROJECT = 'PROJECT'
LIST_TOPICS_PATH = 'projects/%s/topics' % (PROJECT,)
LIST_SUBSCRIPTIONS_PATH = 'projects/%s/subscriptions' % (PROJECT,)
TOPIC_NAME = 'topic_name'
TOPIC_PATH = 'projects/%s/topics/%s' % (PROJECT, TOPIC_NAME)
LIST_TOPIC_SUBSCRIPTIONS_PATH = '%s/subscriptions' % (TOPIC_PATH,)
SUB_NAME = 'subscription_name'
SUB_PATH = 'projects/%s/subscriptions/%s' % (PROJECT, SUB_NAME)
def _makeOne(self, *args, **kw):
return self._getTargetClass()(*args, **kw)
class TestConnection(_Base):
def _getTargetClass(self):
from gcloud.pubsub.connection import Connection
return Connection
def test_default_url(self):
conn = self._makeOne()
klass = self._getTargetClass()
self.assertEqual(conn.api_base_url, klass.API_BASE_URL)
def test_custom_url_from_env(self):
import os
from gcloud._testing import _Monkey
from gcloud.environment_vars import PUBSUB_EMULATOR
HOST = 'localhost:8187'
fake_environ = {PUBSUB_EMULATOR: HOST}
with _Monkey(os, getenv=fake_environ.get):
conn = self._makeOne()
klass = self._getTargetClass()
self.assertNotEqual(conn.api_base_url, klass.API_BASE_URL)
self.assertEqual(conn.api_base_url, 'http://' + HOST)
def test_custom_url_from_constructor(self):
HOST = object()
conn = self._makeOne(api_base_url=HOST)
klass = self._getTargetClass()
self.assertNotEqual(conn.api_base_url, klass.API_BASE_URL)
self.assertEqual(conn.api_base_url, HOST)
def test_custom_url_constructor_and_env(self):
import os
from gcloud._testing import _Monkey
from gcloud.environment_vars import PUBSUB_EMULATOR
HOST1 = object()
HOST2 = object()
fake_environ = {PUBSUB_EMULATOR: HOST1}
with _Monkey(os, getenv=fake_environ.get):
conn = self._makeOne(api_base_url=HOST2)
klass = self._getTargetClass()
self.assertNotEqual(conn.api_base_url, klass.API_BASE_URL)
self.assertNotEqual(conn.api_base_url, HOST1)
self.assertEqual(conn.api_base_url, HOST2)
def test_build_api_url_no_extra_query_params(self):
conn = self._makeOne()
URI = '/'.join([
conn.API_BASE_URL,
conn.API_VERSION,
'foo',
])
self.assertEqual(conn.build_api_url('/foo'), URI)
def test_build_api_url_w_extra_query_params(self):
from six.moves.urllib.parse import parse_qsl
from six.moves.urllib.parse import urlsplit
conn = self._makeOne()
uri = conn.build_api_url('/foo', {'bar': 'baz'})
scheme, netloc, path, qs, _ = urlsplit(uri)
self.assertEqual('%s://%s' % (scheme, netloc), conn.API_BASE_URL)
self.assertEqual(path,
'/'.join(['', conn.API_VERSION, 'foo']))
parms = dict(parse_qsl(qs))
self.assertEqual(parms['bar'], 'baz')
def test_build_api_url_w_base_url_override(self):
base_url1 = 'api-base-url1'
base_url2 = 'api-base-url2'
conn = self._makeOne(api_base_url=base_url1)
URI = '/'.join([
base_url2,
conn.API_VERSION,
'foo',
])
self.assertEqual(conn.build_api_url('/foo', api_base_url=base_url2),
URI)
class Test_PublisherAPI(_Base):
def _getTargetClass(self):
from gcloud.pubsub.connection import _PublisherAPI
return _PublisherAPI
def _makeOne(self, *args, **kw):
return self._getTargetClass()(*args, **kw)
def test_ctor(self):
connection = _Connection()
api = self._makeOne(connection)
self.assertTrue(api._connection is connection)
def test_list_topics_no_paging(self):
RETURNED = {'topics': [{'name': self.TOPIC_PATH}]}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
topics, next_token = api.list_topics(self.PROJECT)
self.assertEqual(len(topics), 1)
topic = topics[0]
self.assertIsInstance(topic, dict)
self.assertEqual(topic['name'], self.TOPIC_PATH)
self.assertEqual(next_token, None)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.LIST_TOPICS_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['query_params'], {})
def test_list_topics_with_paging(self):
TOKEN1 = 'TOKEN1'
TOKEN2 = 'TOKEN2'
SIZE = 1
RETURNED = {
'topics': [{'name': self.TOPIC_PATH}],
'nextPageToken': 'TOKEN2',
}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
topics, next_token = api.list_topics(
self.PROJECT, page_token=TOKEN1, page_size=SIZE)
self.assertEqual(len(topics), 1)
topic = topics[0]
self.assertIsInstance(topic, dict)
self.assertEqual(topic['name'], self.TOPIC_PATH)
self.assertEqual(next_token, TOKEN2)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.LIST_TOPICS_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['query_params'],
{'pageToken': TOKEN1, 'pageSize': SIZE})
def test_list_topics_missing_key(self):
RETURNED = {}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
topics, next_token = api.list_topics(self.PROJECT)
self.assertEqual(len(topics), 0)
self.assertEqual(next_token, None)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.LIST_TOPICS_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['query_params'], {})
def test_topic_create(self):
RETURNED = {'name': self.TOPIC_PATH}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
resource = api.topic_create(self.TOPIC_PATH)
self.assertEqual(resource, RETURNED)
self.assertEqual(connection._called_with['method'], 'PUT')
path = '/%s' % (self.TOPIC_PATH,)
self.assertEqual(connection._called_with['path'], path)
def test_topic_create_already_exists(self):
from gcloud.exceptions import Conflict
connection = _Connection()
connection._no_response_error = Conflict
api = self._makeOne(connection)
with self.assertRaises(Conflict):
api.topic_create(self.TOPIC_PATH)
self.assertEqual(connection._called_with['method'], 'PUT')
path = '/%s' % (self.TOPIC_PATH,)
self.assertEqual(connection._called_with['path'], path)
def test_topic_get_hit(self):
RETURNED = {'name': self.TOPIC_PATH}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
resource = api.topic_get(self.TOPIC_PATH)
self.assertEqual(resource, RETURNED)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.TOPIC_PATH,)
self.assertEqual(connection._called_with['path'], path)
def test_topic_get_miss(self):
from gcloud.exceptions import NotFound
connection = _Connection()
api = self._makeOne(connection)
with self.assertRaises(NotFound):
api.topic_get(self.TOPIC_PATH)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.TOPIC_PATH,)
self.assertEqual(connection._called_with['path'], path)
def test_topic_delete_hit(self):
RETURNED = {}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
api.topic_delete(self.TOPIC_PATH)
self.assertEqual(connection._called_with['method'], 'DELETE')
path = '/%s' % (self.TOPIC_PATH,)
self.assertEqual(connection._called_with['path'], path)
def test_topic_delete_miss(self):
from gcloud.exceptions import NotFound
connection = _Connection()
api = self._makeOne(connection)
with self.assertRaises(NotFound):
api.topic_delete(self.TOPIC_PATH)
self.assertEqual(connection._called_with['method'], 'DELETE')
path = '/%s' % (self.TOPIC_PATH,)
self.assertEqual(connection._called_with['path'], path)
def test_topic_publish_hit(self):
import base64
PAYLOAD = b'This is the message text'
B64 = base64.b64encode(PAYLOAD).decode('ascii')
MSGID = 'DEADBEEF'
MESSAGE = {'data': B64, 'attributes': {}}
RETURNED = {'messageIds': [MSGID]}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
resource = api.topic_publish(self.TOPIC_PATH, [MESSAGE])
self.assertEqual(resource, [MSGID])
self.assertEqual(connection._called_with['method'], 'POST')
path = '/%s:publish' % (self.TOPIC_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['data'],
{'messages': [MESSAGE]})
def test_topic_publish_miss(self):
import base64
from gcloud.exceptions import NotFound
PAYLOAD = b'This is the message text'
B64 = base64.b64encode(PAYLOAD).decode('ascii')
MESSAGE = {'data': B64, 'attributes': {}}
connection = _Connection()
api = self._makeOne(connection)
with self.assertRaises(NotFound):
api.topic_publish(self.TOPIC_PATH, [MESSAGE])
self.assertEqual(connection._called_with['method'], 'POST')
path = '/%s:publish' % (self.TOPIC_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['data'],
{'messages': [MESSAGE]})
def test_topic_list_subscriptions_no_paging(self):
SUB_INFO = {'name': self.SUB_PATH, 'topic': self.TOPIC_PATH}
RETURNED = {'subscriptions': [SUB_INFO]}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
subscriptions, next_token = api.topic_list_subscriptions(
self.TOPIC_PATH)
self.assertEqual(len(subscriptions), 1)
subscription = subscriptions[0]
self.assertIsInstance(subscription, dict)
self.assertEqual(subscription['name'], self.SUB_PATH)
self.assertEqual(subscription['topic'], self.TOPIC_PATH)
self.assertEqual(next_token, None)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.LIST_TOPIC_SUBSCRIPTIONS_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['query_params'], {})
def test_topic_list_subscriptions_with_paging(self):
TOKEN1 = 'TOKEN1'
TOKEN2 = 'TOKEN2'
SIZE = 1
SUB_INFO = {'name': self.SUB_PATH, 'topic': self.TOPIC_PATH}
RETURNED = {
'subscriptions': [SUB_INFO],
'nextPageToken': 'TOKEN2',
}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
subscriptions, next_token = api.topic_list_subscriptions(
self.TOPIC_PATH, page_token=TOKEN1, page_size=SIZE)
self.assertEqual(len(subscriptions), 1)
subscription = subscriptions[0]
self.assertIsInstance(subscription, dict)
self.assertEqual(subscription['name'], self.SUB_PATH)
self.assertEqual(subscription['topic'], self.TOPIC_PATH)
self.assertEqual(next_token, TOKEN2)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.LIST_TOPIC_SUBSCRIPTIONS_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['query_params'],
{'pageToken': TOKEN1, 'pageSize': SIZE})
def test_topic_list_subscriptions_missing_key(self):
RETURNED = {}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
subscriptions, next_token = api.topic_list_subscriptions(
self.TOPIC_PATH)
self.assertEqual(len(subscriptions), 0)
self.assertEqual(next_token, None)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.LIST_TOPIC_SUBSCRIPTIONS_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['query_params'], {})
def test_topic_list_subscriptions_miss(self):
from gcloud.exceptions import NotFound
connection = _Connection()
api = self._makeOne(connection)
with self.assertRaises(NotFound):
api.topic_list_subscriptions(self.TOPIC_PATH)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.LIST_TOPIC_SUBSCRIPTIONS_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['query_params'], {})
class Test_SubscriberAPI(_Base):
def _getTargetClass(self):
from gcloud.pubsub.connection import _SubscriberAPI
return _SubscriberAPI
def _makeOne(self, *args, **kw):
return self._getTargetClass()(*args, **kw)
def test_ctor(self):
connection = _Connection()
api = self._makeOne(connection)
self.assertTrue(api._connection is connection)
def test_list_subscriptions_no_paging(self):
SUB_INFO = {'name': self.SUB_PATH, 'topic': self.TOPIC_PATH}
RETURNED = {'subscriptions': [SUB_INFO]}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
subscriptions, next_token = api.list_subscriptions(self.PROJECT)
self.assertEqual(len(subscriptions), 1)
subscription = subscriptions[0]
self.assertIsInstance(subscription, dict)
self.assertEqual(subscription['name'], self.SUB_PATH)
self.assertEqual(subscription['topic'], self.TOPIC_PATH)
self.assertEqual(next_token, None)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.LIST_SUBSCRIPTIONS_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['query_params'], {})
def test_list_subscriptions_with_paging(self):
TOKEN1 = 'TOKEN1'
TOKEN2 = 'TOKEN2'
SIZE = 1
SUB_INFO = {'name': self.SUB_PATH, 'topic': self.TOPIC_PATH}
RETURNED = {
'subscriptions': [SUB_INFO],
'nextPageToken': 'TOKEN2',
}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
subscriptions, next_token = api.list_subscriptions(
self.PROJECT, page_token=TOKEN1, page_size=SIZE)
self.assertEqual(len(subscriptions), 1)
subscription = subscriptions[0]
self.assertIsInstance(subscription, dict)
self.assertEqual(subscription['name'], self.SUB_PATH)
self.assertEqual(subscription['topic'], self.TOPIC_PATH)
self.assertEqual(next_token, TOKEN2)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.LIST_SUBSCRIPTIONS_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['query_params'],
{'pageToken': TOKEN1, 'pageSize': SIZE})
def test_list_subscriptions_missing_key(self):
RETURNED = {}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
subscriptions, next_token = api.list_subscriptions(self.PROJECT)
self.assertEqual(len(subscriptions), 0)
self.assertEqual(next_token, None)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.LIST_SUBSCRIPTIONS_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['query_params'], {})
def test_subscription_create_defaults(self):
RESOURCE = {'topic': self.TOPIC_PATH}
RETURNED = RESOURCE.copy()
RETURNED['name'] = self.SUB_PATH
connection = _Connection(RETURNED)
api = self._makeOne(connection)
resource = api.subscription_create(self.SUB_PATH, self.TOPIC_PATH)
self.assertEqual(resource, RETURNED)
self.assertEqual(connection._called_with['method'], 'PUT')
path = '/%s' % (self.SUB_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['data'], RESOURCE)
def test_subscription_create_explicit(self):
ACK_DEADLINE = 90
PUSH_ENDPOINT = 'https://api.example.com/push'
RESOURCE = {
'topic': self.TOPIC_PATH,
'ackDeadlineSeconds': ACK_DEADLINE,
'pushConfig': {
'pushEndpoint': PUSH_ENDPOINT,
},
}
RETURNED = RESOURCE.copy()
RETURNED['name'] = self.SUB_PATH
connection = _Connection(RETURNED)
api = self._makeOne(connection)
resource = api.subscription_create(
self.SUB_PATH, self.TOPIC_PATH,
ack_deadline=ACK_DEADLINE, push_endpoint=PUSH_ENDPOINT)
self.assertEqual(resource, RETURNED)
self.assertEqual(connection._called_with['method'], 'PUT')
path = '/%s' % (self.SUB_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['data'], RESOURCE)
def test_subscription_get(self):
ACK_DEADLINE = 90
PUSH_ENDPOINT = 'https://api.example.com/push'
RETURNED = {
'topic': self.TOPIC_PATH,
'name': self.SUB_PATH,
'ackDeadlineSeconds': ACK_DEADLINE,
'pushConfig': {'pushEndpoint': PUSH_ENDPOINT},
}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
resource = api.subscription_get(self.SUB_PATH)
self.assertEqual(resource, RETURNED)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s' % (self.SUB_PATH,)
self.assertEqual(connection._called_with['path'], path)
def test_subscription_delete(self):
RETURNED = {}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
api.subscription_delete(self.SUB_PATH)
self.assertEqual(connection._called_with['method'], 'DELETE')
path = '/%s' % (self.SUB_PATH,)
self.assertEqual(connection._called_with['path'], path)
def test_subscription_modify_push_config(self):
PUSH_ENDPOINT = 'https://api.example.com/push'
BODY = {
'pushConfig': {'pushEndpoint': PUSH_ENDPOINT},
}
RETURNED = {}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
api.subscription_modify_push_config(self.SUB_PATH, PUSH_ENDPOINT)
self.assertEqual(connection._called_with['method'], 'POST')
path = '/%s:modifyPushConfig' % (self.SUB_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['data'], BODY)
def test_subscription_pull_defaults(self):
import base64
PAYLOAD = b'This is the message text'
B64 = base64.b64encode(PAYLOAD).decode('ascii')
ACK_ID = 'DEADBEEF'
MSG_ID = 'BEADCAFE'
MESSAGE = {'messageId': MSG_ID, 'data': B64, 'attributes': {'a': 'b'}}
RETURNED = {
'receivedMessages': [{'ackId': ACK_ID, 'message': MESSAGE}],
}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
BODY = {
'returnImmediately': False,
'maxMessages': 1,
}
received = api.subscription_pull(self.SUB_PATH)
self.assertEqual(received, RETURNED['receivedMessages'])
self.assertEqual(connection._called_with['method'], 'POST')
path = '/%s:pull' % (self.SUB_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['data'], BODY)
def test_subscription_pull_explicit(self):
import base64
PAYLOAD = b'This is the message text'
B64 = base64.b64encode(PAYLOAD).decode('ascii')
ACK_ID = 'DEADBEEF'
MSG_ID = 'BEADCAFE'
MESSAGE = {'messageId': MSG_ID, 'data': B64, 'attributes': {'a': 'b'}}
RETURNED = {
'receivedMessages': [{'ackId': ACK_ID, 'message': MESSAGE}],
}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
MAX_MESSAGES = 10
BODY = {
'returnImmediately': True,
'maxMessages': MAX_MESSAGES,
}
received = api.subscription_pull(
self.SUB_PATH, return_immediately=True, max_messages=MAX_MESSAGES)
self.assertEqual(received, RETURNED['receivedMessages'])
self.assertEqual(connection._called_with['method'], 'POST')
path = '/%s:pull' % (self.SUB_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['data'], BODY)
def test_subscription_acknowledge(self):
ACK_ID1 = 'DEADBEEF'
ACK_ID2 = 'BEADCAFE'
BODY = {
'ackIds': [ACK_ID1, ACK_ID2],
}
RETURNED = {}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
api.subscription_acknowledge(self.SUB_PATH, [ACK_ID1, ACK_ID2])
self.assertEqual(connection._called_with['method'], 'POST')
path = '/%s:acknowledge' % (self.SUB_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['data'], BODY)
def test_subscription_modify_ack_deadline(self):
ACK_ID1 = 'DEADBEEF'
ACK_ID2 = 'BEADCAFE'
NEW_DEADLINE = 90
BODY = {
'ackIds': [ACK_ID1, ACK_ID2],
'ackDeadlineSeconds': NEW_DEADLINE,
}
RETURNED = {}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
api.subscription_modify_ack_deadline(
self.SUB_PATH, [ACK_ID1, ACK_ID2], NEW_DEADLINE)
self.assertEqual(connection._called_with['method'], 'POST')
path = '/%s:modifyAckDeadline' % (self.SUB_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['data'], BODY)
class Test_IAMPolicyAPI(_Base):
def _getTargetClass(self):
from gcloud.pubsub.connection import _IAMPolicyAPI
return _IAMPolicyAPI
def test_ctor(self):
connection = _Connection()
api = self._makeOne(connection)
self.assertTrue(api._connection is connection)
def test_get_iam_policy(self):
from gcloud.pubsub.iam import OWNER_ROLE, EDITOR_ROLE, VIEWER_ROLE
OWNER1 = 'user:phred@example.com'
OWNER2 = 'group:cloud-logs@google.com'
EDITOR1 = 'domain:google.com'
EDITOR2 = 'user:phred@example.com'
VIEWER1 = 'serviceAccount:1234-abcdef@service.example.com'
VIEWER2 = 'user:phred@example.com'
RETURNED = {
'etag': 'DEADBEEF',
'version': 17,
'bindings': [
{'role': OWNER_ROLE, 'members': [OWNER1, OWNER2]},
{'role': EDITOR_ROLE, 'members': [EDITOR1, EDITOR2]},
{'role': VIEWER_ROLE, 'members': [VIEWER1, VIEWER2]},
],
}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
policy = api.get_iam_policy(self.TOPIC_PATH)
self.assertEqual(policy, RETURNED)
self.assertEqual(connection._called_with['method'], 'GET')
path = '/%s:getIamPolicy' % (self.TOPIC_PATH,)
self.assertEqual(connection._called_with['path'], path)
def test_set_iam_policy(self):
from gcloud.pubsub.iam import OWNER_ROLE, EDITOR_ROLE, VIEWER_ROLE
OWNER1 = 'user:phred@example.com'
OWNER2 = 'group:cloud-logs@google.com'
EDITOR1 = 'domain:google.com'
EDITOR2 = 'user:phred@example.com'
VIEWER1 = 'serviceAccount:1234-abcdef@service.example.com'
VIEWER2 = 'user:phred@example.com'
POLICY = {
'etag': 'DEADBEEF',
'version': 17,
'bindings': [
{'role': OWNER_ROLE, 'members': [OWNER1, OWNER2]},
{'role': EDITOR_ROLE, 'members': [EDITOR1, EDITOR2]},
{'role': VIEWER_ROLE, 'members': [VIEWER1, VIEWER2]},
],
}
RETURNED = POLICY.copy()
connection = _Connection(RETURNED)
api = self._makeOne(connection)
policy = api.set_iam_policy(self.TOPIC_PATH, POLICY)
self.assertEqual(policy, RETURNED)
self.assertEqual(connection._called_with['method'], 'POST')
path = '/%s:setIamPolicy' % (self.TOPIC_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['data'],
{'policy': POLICY})
def test_test_iam_permissions(self):
from gcloud.pubsub.iam import OWNER_ROLE, EDITOR_ROLE, VIEWER_ROLE
ALL_ROLES = [OWNER_ROLE, EDITOR_ROLE, VIEWER_ROLE]
ALLOWED = ALL_ROLES[1:]
RETURNED = {'permissions': ALLOWED}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
allowed = api.test_iam_permissions(self.TOPIC_PATH, ALL_ROLES)
self.assertEqual(allowed, ALLOWED)
self.assertEqual(connection._called_with['method'], 'POST')
path = '/%s:testIamPermissions' % (self.TOPIC_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['data'],
{'permissions': ALL_ROLES})
def test_test_iam_permissions_missing_key(self):
from gcloud.pubsub.iam import OWNER_ROLE, EDITOR_ROLE, VIEWER_ROLE
ALL_ROLES = [OWNER_ROLE, EDITOR_ROLE, VIEWER_ROLE]
RETURNED = {}
connection = _Connection(RETURNED)
api = self._makeOne(connection)
allowed = api.test_iam_permissions(self.TOPIC_PATH, ALL_ROLES)
self.assertEqual(allowed, [])
self.assertEqual(connection._called_with['method'], 'POST')
path = '/%s:testIamPermissions' % (self.TOPIC_PATH,)
self.assertEqual(connection._called_with['path'], path)
self.assertEqual(connection._called_with['data'],
{'permissions': ALL_ROLES})
class _Connection(object):
_called_with = None
_no_response_error = None
def __init__(self, *responses):
self._responses = responses
def api_request(self, **kw):
from gcloud.exceptions import NotFound
self._called_with = kw
try:
response, self._responses = self._responses[0], self._responses[1:]
except IndexError:
err_class = self._no_response_error or NotFound
raise err_class('miss')
return response