io.streamthoughts.kafka.connect.filepulse.state.FileObjectStateBackingStoreManager Maven / Gradle / Ivy
/*
* Copyright 2021 StreamThoughts.
*
* 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 io.streamthoughts.kafka.connect.filepulse.state;
import io.streamthoughts.kafka.connect.filepulse.source.FileObject;
import io.streamthoughts.kafka.connect.filepulse.state.internal.OpaqueMemoryResource;
import io.streamthoughts.kafka.connect.filepulse.state.internal.ResourceDisposer;
import io.streamthoughts.kafka.connect.filepulse.state.internal.ResourceInitializer;
import io.streamthoughts.kafka.connect.filepulse.storage.KafkaStateBackingStore;
import io.streamthoughts.kafka.connect.filepulse.storage.StateBackingStore;
import org.slf4j.Logger;
import org.slf4j.LoggerFactory;
import java.util.HashSet;
import java.util.Objects;
import java.util.concurrent.ConcurrentHashMap;
import java.util.concurrent.atomic.AtomicBoolean;
import java.util.concurrent.locks.ReentrantLock;
/**
* The {@code StateBackingStoreManager} is used to manage {@link StateBackingStore} shared
* across Connector and Tasks instances.
*/
public final class FileObjectStateBackingStoreManager {
public static final FileObjectStateBackingStoreManager INSTANCE = new FileObjectStateBackingStoreManager();
private static final Logger LOG = LoggerFactory.getLogger(FileObjectStateBackingStoreManager.class);
private final ReentrantLock lock = new ReentrantLock();
private final ConcurrentHashMap>> leasedResources =
new ConcurrentHashMap<>();
/**
* Gets the shared {@link FileObjectStateBackingStoreManager} and registers a lease.
* If the object does not yet exist, it will be created through the given initializer.
*
* @param name the store name.
* @param initializer the initializer function.
* @param leaseHolder the lease to register.
*
* @return the shared {@link KafkaStateBackingStore}.
*/
public OpaqueMemoryResource> getOrCreateSharedStore(
final String name,
final ResourceInitializer> initializer,
final Object leaseHolder
) throws Exception {
lock.lock();
try {
LeasedResource> leasedResource = this.leasedResources.get(name);
if (leasedResource == null) {
LOG.info("Initializing shared StateBackingStore '{}'", name);
StateBackingStore resource = initializer.apply();
leasedResource = new LeasedResource<>(resource);
this.leasedResources.put(name, leasedResource);
}
leasedResource.addLeaseHolder(leaseHolder);
ResourceDisposer disposer = () -> release(name, leaseHolder);
return new OpaqueMemoryResource<>(leasedResource.getResource(), disposer);
} finally {
lock.unlock();
}
}
void release(final String name, final Object leaseHolder) throws Exception {
lock.lock();
try {
LeasedResource> leasedResource = this.leasedResources.get(name);
if (leasedResource == null) {
return;
}
final String threadName = Thread.currentThread().getName();
LOG.info("[{}] Releasing access on shared StateBackingStore '{}' instance.", name, threadName);
if (leasedResource.removeLeaseHolder(leaseHolder)) {
LOG.info("[{}] Closing shared StateBackingStore '{}'", name, threadName);
leasedResource.close();
leasedResources.remove(name);
}
} finally {
lock.unlock();
}
}
private final static class LeasedResource implements AutoCloseable {
private final T resource;
private final HashSet
© 2015 - 2024 Weber Informatics LLC | Privacy Policy