All Downloads are FREE. Search and download functionalities are using the official Maven repository.

org.apache.pulsar.client.admin.internal.SourcesImpl Maven / Gradle / Ivy

There is a newer version: 4.0.0-preview.1
Show newest version
/*
 * Licensed to the Apache Software Foundation (ASF) under one
 * or more contributor license agreements.  See the NOTICE file
 * distributed with this work for additional information
 * regarding copyright ownership.  The ASF licenses this file
 * to you under the Apache License, Version 2.0 (the
 * "License"); you may not use this file except in compliance
 * with the License.  You may obtain a copy of the License at
 *
 *   http://www.apache.org/licenses/LICENSE-2.0
 *
 * Unless required by applicable law or agreed to in writing,
 * software distributed under the License is distributed on an
 * "AS IS" BASIS, WITHOUT WARRANTIES OR CONDITIONS OF ANY
 * KIND, either express or implied.  See the License for the
 * specific language governing permissions and limitations
 * under the License.
 */
package org.apache.pulsar.client.admin.internal;

import static org.apache.pulsar.shade.org.asynchttpclient.Dsl.post;
import static org.apache.pulsar.shade.org.asynchttpclient.Dsl.put;
import org.apache.pulsar.shade.com.google.gson.Gson;
import java.io.File;
import java.util.List;
import java.util.concurrent.CompletableFuture;
import org.apache.pulsar.shade.javax.ws.rs.client.Entity;
import org.apache.pulsar.shade.javax.ws.rs.client.WebTarget;
import org.apache.pulsar.shade.javax.ws.rs.core.GenericType;
import org.apache.pulsar.shade.javax.ws.rs.core.MediaType;
import org.apache.pulsar.shade.javax.ws.rs.core.Response;
import lombok.extern.slf4j.Slf4j;
import org.apache.pulsar.client.admin.PulsarAdminException;
import org.apache.pulsar.client.admin.Source;
import org.apache.pulsar.client.admin.Sources;
import org.apache.pulsar.client.api.Authentication;
import org.apache.pulsar.common.functions.UpdateOptions;
import org.apache.pulsar.common.functions.UpdateOptionsImpl;
import org.apache.pulsar.common.io.ConnectorDefinition;
import org.apache.pulsar.common.io.SourceConfig;
import org.apache.pulsar.common.policies.data.SourceStatus;
import org.apache.pulsar.shade.org.asynchttpclient.AsyncHttpClient;
import org.apache.pulsar.shade.org.asynchttpclient.RequestBuilder;
import org.apache.pulsar.shade.org.asynchttpclient.request.body.multipart.FilePart;
import org.apache.pulsar.shade.org.asynchttpclient.request.body.multipart.StringPart;
import org.apache.pulsar.shade.org.glassfish.jersey.media.multipart.FormDataBodyPart;
import org.apache.pulsar.shade.org.glassfish.jersey.media.multipart.FormDataMultiPart;

@Slf4j
public class SourcesImpl extends ComponentResource implements Sources, Source {

    private final WebTarget source;
    private final AsyncHttpClient asyncHttpClient;

    public SourcesImpl(WebTarget web, Authentication auth, AsyncHttpClient asyncHttpClient, long readTimeoutMs) {
        super(auth, readTimeoutMs);
        this.source = web.path("/admin/v3/source");
        this.asyncHttpClient = asyncHttpClient;
    }

    @Override
    public List listSources(String tenant, String namespace) throws PulsarAdminException {
        return sync(() -> listSourcesAsync(tenant, namespace));
    }

    @Override
    public CompletableFuture> listSourcesAsync(String tenant, String namespace) {
        WebTarget path = source.path(tenant).path(namespace);
        return asyncGetRequest(path, new GenericType>() {});
    }

    @Override
    public SourceConfig getSource(String tenant, String namespace, String sourceName) throws PulsarAdminException {
        return sync(() -> getSourceAsync(tenant, namespace, sourceName));
    }

    @Override
    public CompletableFuture getSourceAsync(String tenant, String namespace, String sourceName) {
        WebTarget path = source.path(tenant).path(namespace).path(sourceName);
        return asyncGetRequest(path, SourceConfig.class);
    }

    @Override
    public SourceStatus getSourceStatus(
            String tenant, String namespace, String sourceName) throws PulsarAdminException {
        return sync(() -> getSourceStatusAsync(tenant, namespace, sourceName));
    }

    @Override
    public CompletableFuture getSourceStatusAsync(String tenant, String namespace, String sourceName) {
        WebTarget path = source.path(tenant).path(namespace).path(sourceName).path("status");
        return asyncGetRequest(path, SourceStatus.class);
    }

    @Override
    public SourceStatus.SourceInstanceStatus.SourceInstanceStatusData getSourceStatus(
            String tenant, String namespace, String sourceName, int id) throws PulsarAdminException {
        return sync(() -> getSourceStatusAsync(tenant, namespace, sourceName, id));
    }

    @Override
    public CompletableFuture getSourceStatusAsync(
            String tenant, String namespace, String sourceName, int id) {
        WebTarget path = source.path(tenant).path(namespace).path(sourceName).path(Integer.toString(id)).path("status");
        return asyncGetRequest(path, SourceStatus.SourceInstanceStatus.SourceInstanceStatusData.class);
    }

    @Override
    public void createSource(SourceConfig sourceConfig, String fileName) throws PulsarAdminException {
        sync(() -> createSourceAsync(sourceConfig, fileName));
    }

    @Override
    public CompletableFuture createSourceAsync(SourceConfig sourceConfig, String fileName) {
        final CompletableFuture future = new CompletableFuture<>();
        try {
            RequestBuilder builder =
                    post(source.path(sourceConfig.getTenant())
                            .path(sourceConfig.getNamespace()).path(sourceConfig.getName()).getUri().toASCIIString())
                    .addBodyPart(new StringPart("sourceConfig", objectWriter()
                            .writeValueAsString(sourceConfig), MediaType.APPLICATION_JSON));

            if (fileName != null && !fileName.startsWith("builtin://")) {
                // If the function code is built in, we don't need to submit here
                builder.addBodyPart(new FilePart("data", new File(fileName), MediaType.APPLICATION_OCTET_STREAM));
            }
            asyncHttpClient.executeRequest(addAuthHeaders(source, builder).build())
                    .toCompletableFuture()
                    .thenAccept(response -> {
                        if (response.getStatusCode() < 200 || response.getStatusCode() >= 300) {
                            future.completeExceptionally(
                                    getApiException(Response
                                            .status(response.getStatusCode())
                                            .entity(response.getResponseBody()).build()));
                        } else {
                            future.complete(null);
                        }
                    })
                    .exceptionally(throwable -> {
                        future.completeExceptionally(getApiException(throwable));
                        return null;
                    });
        } catch (Exception e) {
            future.completeExceptionally(getApiException(e));
        }
        return future;
    }

    @Override
    public void createSourceWithUrl(SourceConfig sourceConfig, String pkgUrl) throws PulsarAdminException {
        sync(() -> createSourceWithUrlAsync(sourceConfig, pkgUrl));
    }

    @Override
    public CompletableFuture createSourceWithUrlAsync(SourceConfig sourceConfig, String pkgUrl) {
        final FormDataMultiPart mp = new FormDataMultiPart();
        mp.bodyPart(new FormDataBodyPart("url", pkgUrl, MediaType.TEXT_PLAIN_TYPE));
        mp.bodyPart(new FormDataBodyPart("sourceConfig",
                new Gson().toJson(sourceConfig),
                MediaType.APPLICATION_JSON_TYPE));
        WebTarget path = source.path(sourceConfig.getTenant())
                .path(sourceConfig.getNamespace()).path(sourceConfig.getName());
        return asyncPostRequest(path, Entity.entity(mp, MediaType.MULTIPART_FORM_DATA));
    }

    @Override
    public void deleteSource(String cluster, String namespace, String function) throws PulsarAdminException {
        sync(() -> deleteSourceAsync(cluster, namespace, function));
    }

    @Override
    public CompletableFuture deleteSourceAsync(String tenant, String namespace, String function) {
        WebTarget path = source.path(tenant).path(namespace).path(function);
        return asyncDeleteRequest(path);
    }

    @Override
    public void updateSource(SourceConfig sourceConfig, String fileName, UpdateOptions updateOptions)
            throws PulsarAdminException {
        sync(() -> updateSourceAsync(sourceConfig, fileName, updateOptions));
    }

    @Override
    public CompletableFuture updateSourceAsync(
            SourceConfig sourceConfig, String fileName, UpdateOptions updateOptions) {
        final CompletableFuture future = new CompletableFuture<>();
        try {
            RequestBuilder builder =
                    put(source.path(sourceConfig.getTenant()).path(sourceConfig.getNamespace())
                            .path(sourceConfig.getName()).getUri().toASCIIString())
                    .addBodyPart(new StringPart("sourceConfig", objectWriter()
                            .writeValueAsString(sourceConfig), MediaType.APPLICATION_JSON));

            UpdateOptionsImpl options = (UpdateOptionsImpl) updateOptions;
            if (options != null) {
                builder.addBodyPart(new StringPart("updateOptions",
                        objectWriter().writeValueAsString(options),
                        MediaType.APPLICATION_JSON));
            }

            if (fileName != null && !fileName.startsWith("builtin://")) {
                // If the function code is built in, we don't need to submit here
                builder.addBodyPart(new FilePart("data", new File(fileName), MediaType.APPLICATION_OCTET_STREAM));
            }
            asyncHttpClient.executeRequest(addAuthHeaders(source, builder).build())
                    .toCompletableFuture()
                    .thenAccept(response -> {
                        if (response.getStatusCode() < 200 || response.getStatusCode() >= 300) {
                            future.completeExceptionally(
                                    getApiException(Response
                                            .status(response.getStatusCode())
                                            .entity(response.getResponseBody()).build()));
                        } else {
                            future.complete(null);
                        }
                    })
                    .exceptionally(throwable -> {
                        future.completeExceptionally(getApiException(throwable));
                        return null;
                    });
        } catch (Exception e) {
            future.completeExceptionally(getApiException(e));
        }
        return future;
    }

    @Override
    public void updateSource(SourceConfig sourceConfig, String fileName) throws PulsarAdminException {
        updateSource(sourceConfig, fileName, null);
    }

    @Override
    public CompletableFuture updateSourceAsync(SourceConfig sourceConfig, String fileName) {
        return updateSourceAsync(sourceConfig, fileName, null);
    }

    @Override
    public void updateSourceWithUrl(SourceConfig sourceConfig, String pkgUrl, UpdateOptions updateOptions)
            throws PulsarAdminException {
        sync(() -> updateSourceWithUrlAsync(sourceConfig, pkgUrl, updateOptions));
    }

    @Override
    public CompletableFuture updateSourceWithUrlAsync(
            SourceConfig sourceConfig, String pkgUrl, UpdateOptions updateOptions) {
        final CompletableFuture future = new CompletableFuture<>();
        try {
            final FormDataMultiPart mp = new FormDataMultiPart();
            mp.bodyPart(new FormDataBodyPart("url", pkgUrl, MediaType.TEXT_PLAIN_TYPE));
            mp.bodyPart(new FormDataBodyPart(
                    "sourceConfig",
                    new Gson().toJson(sourceConfig),
                    MediaType.APPLICATION_JSON_TYPE));
            UpdateOptionsImpl options = (UpdateOptionsImpl) updateOptions;
            if (options != null) {
                mp.bodyPart(new FormDataBodyPart(
                        "updateOptions",
                        objectWriter().writeValueAsString(options),
                        MediaType.APPLICATION_JSON_TYPE));
            }
            WebTarget path = source.path(sourceConfig.getTenant()).path(sourceConfig.getNamespace())
                    .path(sourceConfig.getName());
            return asyncPutRequest(path, Entity.entity(mp, MediaType.MULTIPART_FORM_DATA));
        } catch (Exception e) {
            future.completeExceptionally(getApiException(e));
        }
        return future;
    }

    @Override
    public void updateSourceWithUrl(SourceConfig sourceConfig, String pkgUrl) throws PulsarAdminException {
        updateSourceWithUrl(sourceConfig, pkgUrl, null);
    }

    @Override
    public CompletableFuture updateSourceWithUrlAsync(SourceConfig sourceConfig, String pkgUrl) {
        return updateSourceWithUrlAsync(sourceConfig, pkgUrl, null);
    }

    @Override
    public void restartSource(String tenant, String namespace, String functionName, int instanceId)
            throws PulsarAdminException {
        sync(() -> restartSourceAsync(tenant, namespace, functionName, instanceId));
    }

    @Override
    public CompletableFuture restartSourceAsync(
            String tenant, String namespace, String functionName, int instanceId) {
        WebTarget path = source.path(tenant).path(namespace).path(functionName).path(Integer.toString(instanceId))
                .path("restart");
        return asyncPostRequest(path, Entity.entity("", MediaType.APPLICATION_JSON));
    }

    @Override
    public void restartSource(String tenant, String namespace, String functionName) throws PulsarAdminException {
        sync(() -> restartSourceAsync(tenant, namespace, functionName));
    }

    @Override
    public CompletableFuture restartSourceAsync(String tenant, String namespace, String functionName) {
        WebTarget path = source.path(tenant).path(namespace).path(functionName).path("restart");
        return asyncPostRequest(path, Entity.entity("", MediaType.APPLICATION_JSON));
    }

    @Override
    public void stopSource(String tenant, String namespace, String sourceName, int instanceId)
            throws PulsarAdminException {
        sync(() -> stopSourceAsync(tenant, namespace, sourceName, instanceId));
    }

    @Override
    public CompletableFuture stopSourceAsync(String tenant, String namespace, String sourceName, int instanceId) {
        WebTarget path = source.path(tenant).path(namespace).path(sourceName).path(Integer.toString(instanceId))
                .path("stop");
        return asyncPostRequest(path, Entity.entity("", MediaType.APPLICATION_JSON));
    }

    @Override
    public void stopSource(String tenant, String namespace, String sourceName) throws PulsarAdminException {
        sync(() -> stopSourceAsync(tenant, namespace, sourceName));
    }

    @Override
    public CompletableFuture stopSourceAsync(String tenant, String namespace, String sourceName) {
        WebTarget path = source.path(tenant).path(namespace).path(sourceName).path("stop");
        return asyncPostRequest(path, Entity.entity("", MediaType.APPLICATION_JSON));
    }

    @Override
    public void startSource(String tenant, String namespace, String sourceName, int instanceId)
            throws PulsarAdminException {
        sync(() -> startSourceAsync(tenant, namespace, sourceName, instanceId));
    }

    @Override
    public CompletableFuture startSourceAsync(
            String tenant, String namespace, String sourceName, int instanceId) {
        WebTarget path = source.path(tenant).path(namespace).path(sourceName).path(Integer.toString(instanceId))
                .path("start");
        return asyncPostRequest(path, Entity.entity("", MediaType.APPLICATION_JSON));
    }

    @Override
    public void startSource(String tenant, String namespace, String sourceName) throws PulsarAdminException {
        sync(() -> startSourceAsync(tenant, namespace, sourceName));
    }

    @Override
    public CompletableFuture startSourceAsync(String tenant, String namespace, String sourceName) {
        WebTarget path = source.path(tenant).path(namespace).path(sourceName).path("start");
        return asyncPostRequest(path, Entity.entity("", MediaType.APPLICATION_JSON));
    }

    @Override
    public List getBuiltInSources() throws PulsarAdminException {
        return sync(() -> getBuiltInSourcesAsync());
    }

    @Override
    public CompletableFuture> getBuiltInSourcesAsync() {
        WebTarget path = source.path("builtinsources");
        final CompletableFuture> future = new CompletableFuture<>();
        return asyncGetRequest(path, new GenericType>() {});
    }

    @Override
    public void reloadBuiltInSources() throws PulsarAdminException {
        sync(() -> reloadBuiltInSourcesAsync());
    }

    @Override
    public CompletableFuture reloadBuiltInSourcesAsync() {
        WebTarget path = source.path("reloadBuiltInSources");
        return asyncPostRequest(path, Entity.entity("", MediaType.APPLICATION_JSON));
    }
}




© 2015 - 2024 Weber Informatics LLC | Privacy Policy