
org.glowroot.agent.server.ServerConnection Maven / Gradle / Ivy
Go to download
Show more of this group Show more artifacts with this name
Show all versions of glowroot-agent-it-harness Show documentation
Show all versions of glowroot-agent-it-harness Show documentation
Glowroot Agent Integration Test Harness
/*
* Copyright 2015-2016 the original author or authors.
*
* 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 org.glowroot.agent.server;
import java.util.Random;
import java.util.concurrent.ExecutorService;
import java.util.concurrent.Executors;
import java.util.concurrent.ScheduledExecutorService;
import org.glowroot.agent.shaded.google.common.base.Stopwatch;
import org.glowroot.agent.shaded.google.common.util.concurrent.ThreadFactoryBuilder;
import org.glowroot.agent.shaded.grpc.ManagedChannel;
import org.glowroot.agent.shaded.grpc.netty.NegotiationType;
import org.glowroot.agent.shaded.grpc.netty.NettyChannelBuilder;
import org.glowroot.agent.shaded.grpc.stub.StreamObserver;
import org.glowroot.agent.shaded.netty.channel.EventLoopGroup;
import org.glowroot.agent.shaded.slf4j.Logger;
import org.glowroot.agent.shaded.slf4j.LoggerFactory;
import org.glowroot.agent.shaded.glowroot.common.util.OnlyUsedByTests;
import static java.util.concurrent.TimeUnit.SECONDS;
class ServerConnection {
private static final Logger logger = LoggerFactory.getLogger(ServerConnection.class);
@SuppressWarnings("nullness:type.argument.type.incompatible")
private final ThreadLocal suppressLogCollector = new ThreadLocal() {
@Override
protected Boolean initialValue() {
return false;
}
};
private final EventLoopGroup eventLoopGroup;
private final ExecutorService executor;
private final ManagedChannel channel;
private final ScheduledExecutorService scheduledExecutor;
private final Random random = new Random();
private volatile boolean closed;
ServerConnection(String collectorHost, int collectorPort,
ScheduledExecutorService scheduledExecutor) {
eventLoopGroup = EventLoopGroups.create("Glowroot-grpc-worker-ELG");
executor = Executors.newSingleThreadExecutor(new ThreadFactoryBuilder()
.setDaemon(true)
.setNameFormat("Glowroot-grpc-executor-%d")
.build());
channel = NettyChannelBuilder
.forAddress(collectorHost, collectorPort)
.eventLoopGroup(eventLoopGroup)
.executor(executor)
.negotiationType(NegotiationType.PLAINTEXT)
.build();
this.scheduledExecutor = scheduledExecutor;
}
boolean suppressLogCollector() {
return suppressLogCollector.get();
}
ManagedChannel getChannel() {
return channel;
}
// important that these calls are idempotent (at least in glowroot server implementation)
void callWithAFewRetries(GrpcCall call) {
if (closed) {
return;
}
// TODO revisit retry/backoff after next grpc version
// 60 seconds should be enough time to restart single glowroot server instance without
// losing data (though better to use glowroot server cluster)
//
// this cannot retry over too long a period since it retains memory of rpc message for that
// duration
call.call(new RetryingStreamObserver(call, 60, 60));
}
// important that these calls are idempotent (at least in glowroot server implementation)
void callUntilSuccessful(GrpcCall call) {
if (closed) {
return;
}
call.call(new RetryingStreamObserver(call, 15, -1));
}
void suppressLogCollector(Runnable runnable) {
boolean priorValue = suppressLogCollector.get();
suppressLogCollector.set(true);
try {
runnable.run();
} finally {
suppressLogCollector.set(priorValue);
}
}
@OnlyUsedByTests
void close() {
closed = true;
channel.shutdown();
}
@OnlyUsedByTests
void awaitClose() throws InterruptedException {
if (!channel.awaitTermination(10, SECONDS)) {
throw new IllegalStateException("Could not terminate gRPC channel");
}
executor.shutdown();
if (!executor.awaitTermination(10, SECONDS)) {
throw new IllegalStateException("Could not terminate gRPC executor");
}
if (!eventLoopGroup.shutdownGracefully(0, 0, SECONDS).await(10, SECONDS)) {
throw new IllegalStateException("Could not terminate gRPC event loop group");
}
}
static abstract class GrpcCall {
abstract void call(StreamObserver responseObserver);
void doWithResponse(@SuppressWarnings("unused") T response) {}
}
private class RetryingStreamObserver
implements StreamObserver {
private final GrpcCall grpcCall;
private final int maxSingleDelayInSeconds;
private final int maxTotalInSeconds;
private final Stopwatch stopwatch = Stopwatch.createStarted();
private volatile long nextDelayInSeconds = 1;
private RetryingStreamObserver(GrpcCall grpcCall, int maxSingleDelayInSeconds,
int maxTotalInSeconds) {
this.grpcCall = grpcCall;
this.maxTotalInSeconds = maxTotalInSeconds;
this.maxSingleDelayInSeconds = maxSingleDelayInSeconds;
}
@Override
public void onNext(T value) {
grpcCall.doWithResponse(value);
}
@Override
public void onError(final Throwable t) {
if (closed) {
return;
}
suppressLogCollector(new Runnable() {
@Override
public void run() {
logger.debug(t.getMessage(), t);
}
});
if (maxTotalInSeconds != -1 && stopwatch.elapsed(SECONDS) > maxTotalInSeconds) {
// no logging since DownstreamServiceObserver handles logging glowroot server
// connectivity
return;
}
// TODO revisit retry/backoff after next grpc version
scheduledExecutor.schedule(new Runnable() {
@Override
public void run() {
try {
grpcCall.call(RetryingStreamObserver.this);
} catch (final Throwable t) {
// intentionally capturing InterruptedException here as well to ensure
// reconnect is attempted no matter what
suppressLogCollector(new Runnable() {
@Override
public void run() {
logger.error(t.getMessage(), t);
}
});
}
}
}, nextDelayInSeconds, SECONDS);
// retry delay doubles on average each time, randomized +/- 50%
double randomizedDoubling = 1.5 + random.nextDouble();
nextDelayInSeconds = Math.min((long) (nextDelayInSeconds * randomizedDoubling),
maxSingleDelayInSeconds);
}
@Override
public void onCompleted() {}
}
}
© 2015 - 2025 Weber Informatics LLC | Privacy Policy