Search in sources :

Example 21 with TopicAdminClient

use of com.google.cloud.pubsub.v1.TopicAdminClient in project google-cloud-java by GoogleCloudPlatform.

the class TopicAdminClientSnippets method createTopic.

/** Example of creating a topic. */
public Topic createTopic(String topicId) throws Exception {
    // [START pubsub_create_topic]
    try (TopicAdminClient topicAdminClient = TopicAdminClient.create()) {
        // projectId <=  unique project identifier, eg. "my-project-id"
        // topicId <= "my-topic-id"
        TopicName topicName = TopicName.create(projectId, topicId);
        Topic topic = topicAdminClient.createTopic(topicName);
        return topic;
    }
// [END pubsub_create_topic]
}
Also used : TopicAdminClient(com.google.cloud.pubsub.spi.v1.TopicAdminClient) Topic(com.google.pubsub.v1.Topic) TopicName(com.google.pubsub.v1.TopicName)

Example 22 with TopicAdminClient

use of com.google.cloud.pubsub.v1.TopicAdminClient in project google-cloud-java by GoogleCloudPlatform.

the class ITPubSubSnippets method testPublisherSubscriber.

@Test
public void testPublisherSubscriber() throws Exception {
    TopicName topicName = TopicName.create(ServiceOptions.getDefaultProjectId(), formatForTest("test-topic"));
    SubscriptionName subscriptionName = SubscriptionName.create(ServiceOptions.getDefaultProjectId(), formatForTest("test-subscription"));
    try (TopicAdminClient publisherClient = TopicAdminClient.create();
        SubscriptionAdminClient subscriberClient = SubscriptionAdminClient.create()) {
        publisherClient.createTopic(topicName);
        subscriberClient.createSubscription(subscriptionName, topicName, PushConfig.getDefaultInstance(), 0);
        testPublisherSubscriberHelper(topicName, subscriptionName);
        subscriberClient.deleteSubscription(subscriptionName);
        publisherClient.deleteTopic(topicName);
    }
}
Also used : TopicAdminClient(com.google.cloud.pubsub.spi.v1.TopicAdminClient) SubscriptionAdminClient(com.google.cloud.pubsub.spi.v1.SubscriptionAdminClient) SubscriptionName(com.google.pubsub.v1.SubscriptionName) TopicName(com.google.pubsub.v1.TopicName) Test(org.junit.Test)

Example 23 with TopicAdminClient

use of com.google.cloud.pubsub.v1.TopicAdminClient in project java-docs-samples by GoogleCloudPlatform.

the class ManagerIT method testHttpDeviceState.

@Test
public void testHttpDeviceState() throws Exception {
    final String deviceName = "rsa-device-http-state";
    topic = DeviceRegistryExample.createIotTopic(PROJECT_ID, TOPIC_ID);
    DeviceRegistryExample.createRegistry(CLOUD_REGION, PROJECT_ID, REGISTRY_ID, TOPIC_ID);
    DeviceRegistryExample.createDeviceWithRs256(deviceName, RSA_PATH, PROJECT_ID, CLOUD_REGION, REGISTRY_ID);
    DeviceRegistryExample.listDevices(PROJECT_ID, CLOUD_REGION, REGISTRY_ID);
    // Device bootstrapped, time to connect and run.
    String[] testArgs = { "-project_id=" + PROJECT_ID, "-registry_id=" + REGISTRY_ID, "-device_id=" + deviceName, "-private_key_file=" + PKCS_PATH, "-num_messages=1", "-message_type=state", "-algorithm=RS256" };
    com.example.cloud.iot.examples.HttpExample.main(testArgs);
    // End device test.
    // Assertions
    String got = bout.toString();
    Assert.assertTrue(got.contains("200"));
    Assert.assertTrue(got.contains("OK"));
    // Clean up
    DeviceRegistryExample.deleteDevice(deviceName, PROJECT_ID, CLOUD_REGION, REGISTRY_ID);
    DeviceRegistryExample.deleteRegistry(CLOUD_REGION, PROJECT_ID, REGISTRY_ID);
    try (TopicAdminClient topicAdminClient = TopicAdminClient.create()) {
        topicAdminClient.deleteTopic(topic.getNameAsTopicName());
    }
}
Also used : TopicAdminClient(com.google.cloud.pubsub.v1.TopicAdminClient) Test(org.junit.Test)

Example 24 with TopicAdminClient

use of com.google.cloud.pubsub.v1.TopicAdminClient in project java-docs-samples by GoogleCloudPlatform.

the class ManagerIT method testMqttDeviceEvents.

@Test
public void testMqttDeviceEvents() throws Exception {
    final String deviceName = "rsa-device-mqtt-events";
    topic = DeviceRegistryExample.createIotTopic(PROJECT_ID, TOPIC_ID);
    DeviceRegistryExample.createRegistry(CLOUD_REGION, PROJECT_ID, REGISTRY_ID, TOPIC_ID);
    DeviceRegistryExample.createDeviceWithRs256(deviceName, RSA_PATH, PROJECT_ID, CLOUD_REGION, REGISTRY_ID);
    DeviceRegistryExample.listDevices(PROJECT_ID, CLOUD_REGION, REGISTRY_ID);
    // Device bootstrapped, time to connect and run.
    String[] testArgs = { "-project_id=" + PROJECT_ID, "-registry_id=" + REGISTRY_ID, "-device_id=" + deviceName, "-private_key_file=" + PKCS_PATH, "-message_type=events", "-num_messages=1", "-algorithm=RS256" };
    com.example.cloud.iot.examples.MqttExample.main(testArgs);
    // End device test.
    // Assertions
    String got = bout.toString();
    // 
    // Finished loop successfully. Goodbye!
    Assert.assertTrue(got.contains("Publishing events message 1"));
    Assert.assertTrue(got.contains("Finished loop successfully. Goodbye!"));
    // Clean up
    DeviceRegistryExample.deleteDevice(deviceName, PROJECT_ID, CLOUD_REGION, REGISTRY_ID);
    DeviceRegistryExample.deleteRegistry(CLOUD_REGION, PROJECT_ID, REGISTRY_ID);
    try (TopicAdminClient topicAdminClient = TopicAdminClient.create()) {
        topicAdminClient.deleteTopic(topic.getNameAsTopicName());
    }
}
Also used : TopicAdminClient(com.google.cloud.pubsub.v1.TopicAdminClient) Test(org.junit.Test)

Example 25 with TopicAdminClient

use of com.google.cloud.pubsub.v1.TopicAdminClient in project java-docs-samples by GoogleCloudPlatform.

the class ManagerIT method testHttpDeviceEvent.

// HTTP device tests
@Test
public void testHttpDeviceEvent() throws Exception {
    final String deviceName = "rsa-device-http-event";
    topic = DeviceRegistryExample.createIotTopic(PROJECT_ID, TOPIC_ID);
    DeviceRegistryExample.createRegistry(CLOUD_REGION, PROJECT_ID, REGISTRY_ID, TOPIC_ID);
    DeviceRegistryExample.createDeviceWithRs256(deviceName, RSA_PATH, PROJECT_ID, CLOUD_REGION, REGISTRY_ID);
    DeviceRegistryExample.listDevices(PROJECT_ID, CLOUD_REGION, REGISTRY_ID);
    // Device bootstrapped, time to connect and run.
    String[] testArgs = { "-project_id=" + PROJECT_ID, "-registry_id=" + REGISTRY_ID, "-device_id=" + deviceName, "-private_key_file=" + PKCS_PATH, "-num_messages=1", "-message_type=event", "-algorithm=RS256" };
    com.example.cloud.iot.examples.HttpExample.main(testArgs);
    // End device test.
    // Assertions
    String got = bout.toString();
    Assert.assertTrue(got.contains("200"));
    Assert.assertTrue(got.contains("OK"));
    // Clean up
    DeviceRegistryExample.deleteDevice(deviceName, PROJECT_ID, CLOUD_REGION, REGISTRY_ID);
    DeviceRegistryExample.deleteRegistry(CLOUD_REGION, PROJECT_ID, REGISTRY_ID);
    try (TopicAdminClient topicAdminClient = TopicAdminClient.create()) {
        topicAdminClient.deleteTopic(topic.getNameAsTopicName());
    }
}
Also used : TopicAdminClient(com.google.cloud.pubsub.v1.TopicAdminClient) Test(org.junit.Test)

Aggregations

TopicAdminClient (com.google.cloud.pubsub.v1.TopicAdminClient)19 Test (org.junit.Test)18 TopicAdminClient (com.google.cloud.pubsub.spi.v1.TopicAdminClient)12 TopicName (com.google.pubsub.v1.TopicName)8 Topic (com.google.pubsub.v1.Topic)5 Binding (com.google.iam.v1.Binding)2 Policy (com.google.iam.v1.Policy)2 TestIamPermissionsResponse (com.google.iam.v1.TestIamPermissionsResponse)2 SubscriptionName (com.google.pubsub.v1.SubscriptionName)2 LinkedList (java.util.LinkedList)2 ApiException (com.google.api.gax.rpc.ApiException)1 ListTopicSubscriptionsPagedResponse (com.google.cloud.pubsub.spi.v1.PagedResponseWrappers.ListTopicSubscriptionsPagedResponse)1 ListTopicsPagedResponse (com.google.cloud.pubsub.spi.v1.PagedResponseWrappers.ListTopicsPagedResponse)1 SubscriptionAdminClient (com.google.cloud.pubsub.spi.v1.SubscriptionAdminClient)1 ListTopicSubscriptionsRequest (com.google.pubsub.v1.ListTopicSubscriptionsRequest)1 ListTopicsRequest (com.google.pubsub.v1.ListTopicsRequest)1 ProjectTopicName (com.google.pubsub.v1.ProjectTopicName)1 CallOptions (io.grpc.CallOptions)1 Channel (io.grpc.Channel)1 ClientInterceptor (io.grpc.ClientInterceptor)1