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

io.helidon.config.etcd.internal.client.v3.EtcdV3Client Maven / Gradle / Ivy

There is a newer version: 4.0.10
Show newest version
/*
 * Copyright (c) 2017, 2018 Oracle and/or its affiliates. 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.
 */

package io.helidon.config.etcd.internal.client.v3;

import java.net.URI;
import java.util.Map;
import java.util.concurrent.ConcurrentHashMap;
import java.util.concurrent.Executor;
import java.util.concurrent.TimeUnit;
import java.util.logging.Level;
import java.util.logging.Logger;

import io.helidon.common.reactive.Flow;
import io.helidon.common.reactive.SubmissionPublisher;
import io.helidon.config.etcd.internal.client.EtcdClient;
import io.helidon.config.etcd.internal.client.EtcdClientException;
import io.helidon.config.etcd.internal.client.proto.KVGrpc;
import io.helidon.config.etcd.internal.client.proto.PutRequest;
import io.helidon.config.etcd.internal.client.proto.RangeRequest;
import io.helidon.config.etcd.internal.client.proto.RangeResponse;
import io.helidon.config.etcd.internal.client.proto.WatchCreateRequest;
import io.helidon.config.etcd.internal.client.proto.WatchGrpc;
import io.helidon.config.etcd.internal.client.proto.WatchRequest;
import io.helidon.config.etcd.internal.client.proto.WatchResponse;

import com.google.protobuf.ByteString;
import io.grpc.ManagedChannel;
import io.grpc.ManagedChannelBuilder;
import io.grpc.StatusRuntimeException;
import io.grpc.stub.StreamObserver;

/**
 * Etcd API v3 client.
 */
public class EtcdV3Client implements EtcdClient {

    private static final Logger LOGGER = Logger.getLogger(EtcdV3Client.class.getName());

    private final Map> publishers = new ConcurrentHashMap<>();

    private final ManagedChannel channel;
    private final KVGrpc.KVBlockingStub kvStub;
    private final WatchGrpc.WatchStub watchStub;

    /**
     * Init client with specified target Etcd uri.
     *
     * @param uri target Etcd uri
     */
    public EtcdV3Client(URI uri) {
        ManagedChannelBuilder mcb = ManagedChannelBuilder.forAddress(uri.getHost(), uri.getPort());
        this.channel = mcb.usePlaintext(true).build();

        kvStub = KVGrpc.newBlockingStub(channel);
        watchStub = WatchGrpc.newStub(channel);
    }

    @Override
    public Long revision(String key) throws EtcdClientException {
        RangeRequest.Builder builder = RangeRequest.newBuilder().setKey(ByteString.copyFromUtf8(key));
        try {
            RangeResponse rangeResponse = kvStub.range(builder.build());
            return (rangeResponse.getCount() == 0 ? null : rangeResponse.getKvs(0).getModRevision());
        } catch (StatusRuntimeException e) {
            throw new EtcdClientException("Cannot retrieve a value for the key: " + key, e);
        }
    }
    @Override
    public String get(String key) throws EtcdClientException {
        RangeRequest.Builder builder = RangeRequest.newBuilder().setKey(ByteString.copyFromUtf8(key));
        try {
            RangeResponse rangeResponse = kvStub.range(builder.build());
            return (rangeResponse.getCount() == 0 ? null : rangeResponse.getKvs(0).getValue().toStringUtf8());
        } catch (StatusRuntimeException e) {
            throw new EtcdClientException("Cannot retrieve a value for the key: " + key, e);
        }
    }

    @Override
    public void put(String key, String value) throws EtcdClientException {
        PutRequest.Builder builder = PutRequest.newBuilder()
                .setKey(ByteString.copyFromUtf8(key))
                .setValue(ByteString.copyFromUtf8(value));
        kvStub.put(builder.build());
    }

    @Override
    public Flow.Publisher watch(String key, Executor executor) throws EtcdClientException {
        final SubmissionPublisher publisher = publishers.computeIfAbsent(
                key,
                (k) -> new SubmissionPublisher<>(executor,
                                                 Flow.defaultBufferSize()));

        StreamObserver responseObserver = new StreamObserver() {
            @Override
            public void onNext(WatchResponse value) {
                value.getEventsList().forEach(e -> publisher.submit(e.getKv().getVersion()));
            }

            @Override
            public void onError(Throwable t) {
                publisher.closeExceptionally(t);
            }

            @Override
            public void onCompleted() {
            }
        };

        WatchCreateRequest.Builder builder = WatchCreateRequest.newBuilder().setKey(ByteString.copyFromUtf8(key));
        WatchRequest watchRequest = WatchRequest.newBuilder().setCreateRequest(builder).build();

        //TODO customize executor used by WatchStub to process watch operation - Issue #21
        StreamObserver requestObserver = watchStub.watch(responseObserver);
        requestObserver.onNext(watchRequest);

        return publisher;
    }

    @Override
    public Flow.Publisher watch(String key) throws EtcdClientException {
        return watch(key, Runnable::run //deliver events on current thread
        );
    }

    @Override
    public void close() throws EtcdClientException {
        publishers.values().forEach(SubmissionPublisher::close);
        if (!channel.isShutdown() && !channel.isTerminated()) {
            try {
                channel.awaitTermination(1, TimeUnit.SECONDS);
            } catch (InterruptedException e) {
                LOGGER.log(Level.CONFIG, "Error closing gRPC channel, reason: " + e.getLocalizedMessage(), e);
            } finally {
                channel.shutdown();
            }
        }
    }
}




© 2015 - 2024 Weber Informatics LLC | Privacy Policy