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

com.turbospaces.gcp.pubsub.producer.LoggingCallback Maven / Gradle / Ivy

There is a newer version: 2.0.33
Show newest version
package com.turbospaces.gcp.pubsub.producer;

import java.util.Objects;
import java.util.UUID;

import com.google.common.util.concurrent.FutureCallback;
import com.turbospaces.api.Topic;

import lombok.extern.slf4j.Slf4j;

@Slf4j
public class LoggingCallback implements FutureCallback {
    private final String namespace;
    private final UUID messageId;
    private final Topic topic;
    private final long now;

    public LoggingCallback(String namespace, UUID messageId, Topic topic, long now) {
        this.namespace = Objects.requireNonNull(namespace);
        this.messageId = Objects.requireNonNull(messageId);
        this.topic = Objects.requireNonNull(topic);
        this.now = now;
    }
    @Override
    public void onSuccess(String result) {
        log.debug("({}:{}) has been accepted by PubSub (topic={}, guid={}) in {}ms",
                namespace,
                messageId,
                topic.name(),
                result,
                System.currentTimeMillis() - now);
    }
    @Override
    public void onFailure(Throwable ex) {
        log.error(ex.getMessage(), ex);
    }
}




© 2015 - 2024 Weber Informatics LLC | Privacy Policy