Partial refactoring to netty 5
This commit is contained in:
parent
19b80c3656
commit
59a209cfb5
4
pom.xml
4
pom.xml
@ -104,12 +104,12 @@
|
|||||||
<dependency>
|
<dependency>
|
||||||
<groupId>io.projectreactor</groupId>
|
<groupId>io.projectreactor</groupId>
|
||||||
<artifactId>reactor-core</artifactId>
|
<artifactId>reactor-core</artifactId>
|
||||||
<version>3.4.8</version>
|
<version>3.4.9</version>
|
||||||
</dependency>
|
</dependency>
|
||||||
<dependency>
|
<dependency>
|
||||||
<groupId>io.projectreactor</groupId>
|
<groupId>io.projectreactor</groupId>
|
||||||
<artifactId>reactor-test</artifactId>
|
<artifactId>reactor-test</artifactId>
|
||||||
<version>3.4.8</version>
|
<version>3.4.9</version>
|
||||||
</dependency>
|
</dependency>
|
||||||
<dependency>
|
<dependency>
|
||||||
<groupId>it.cavallium</groupId>
|
<groupId>it.cavallium</groupId>
|
||||||
|
@ -19,27 +19,40 @@
|
|||||||
package org.warp.filesponge;
|
package org.warp.filesponge;
|
||||||
|
|
||||||
import io.netty.buffer.ByteBuf;
|
import io.netty.buffer.ByteBuf;
|
||||||
|
import io.netty.buffer.api.Buffer;
|
||||||
|
import io.netty.buffer.api.Drop;
|
||||||
|
import io.netty.buffer.api.Owned;
|
||||||
|
import io.netty.buffer.api.Send;
|
||||||
|
import io.netty.buffer.api.internal.ResourceSupport;
|
||||||
|
import it.cavallium.dbengine.database.LLEntry;
|
||||||
import java.util.Objects;
|
import java.util.Objects;
|
||||||
|
|
||||||
public final class DataBlock {
|
public final class DataBlock extends ResourceSupport<DataBlock, DataBlock> {
|
||||||
|
|
||||||
public DataBlock(int offset, int length, ByteBuf data) {
|
public static DataBlock of(int offset, int length, Send<Buffer> data) {
|
||||||
try {
|
return new DataBlock(offset, length, data, d -> {});
|
||||||
|
}
|
||||||
|
|
||||||
|
private DataBlock(int offset, int length, Send<Buffer> data, Drop<DataBlock> drop) {
|
||||||
|
super(new DataBlock.CloseOnDrop(drop));
|
||||||
|
try (data) {
|
||||||
this.offset = offset;
|
this.offset = offset;
|
||||||
this.length = length;
|
this.length = length;
|
||||||
this.data = data.retain();
|
this.data = data.receive();
|
||||||
} finally {
|
|
||||||
data.release();
|
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
private final int offset;
|
private final int offset;
|
||||||
private final int length;
|
private final int length;
|
||||||
private final ByteBuf data;
|
private final Buffer data;
|
||||||
|
|
||||||
public ByteBuf getData() {
|
public Send<Buffer> getData() {
|
||||||
assert data.isReadable();
|
assert data.isAccessible();
|
||||||
return data.retain();
|
return data.copy().send();
|
||||||
|
}
|
||||||
|
|
||||||
|
public Buffer getDataUnsafe() {
|
||||||
|
return data;
|
||||||
}
|
}
|
||||||
|
|
||||||
public int getId() {
|
public int getId() {
|
||||||
@ -90,11 +103,32 @@ public final class DataBlock {
|
|||||||
return "DataBlock(offset=" + this.getOffset() + ", length=" + this.getLength() + ", data=" + this.getData() + ")";
|
return "DataBlock(offset=" + this.getOffset() + ", length=" + this.getLength() + ", data=" + this.getData() + ")";
|
||||||
}
|
}
|
||||||
|
|
||||||
public void retain() {
|
@Override
|
||||||
this.data.retain();
|
protected RuntimeException createResourceClosedException() {
|
||||||
|
return new IllegalStateException("Closed");
|
||||||
}
|
}
|
||||||
|
|
||||||
public void release() {
|
@Override
|
||||||
this.data.release();
|
protected Owned<DataBlock> prepareSend() {
|
||||||
|
Send<Buffer> dataSend;
|
||||||
|
dataSend = this.data.send();
|
||||||
|
return drop -> new DataBlock(offset, length, dataSend, drop);
|
||||||
|
}
|
||||||
|
|
||||||
|
private static class CloseOnDrop implements Drop<DataBlock> {
|
||||||
|
|
||||||
|
private final Drop<DataBlock> delegate;
|
||||||
|
|
||||||
|
public CloseOnDrop(Drop<DataBlock> drop) {
|
||||||
|
this.delegate = drop;
|
||||||
|
}
|
||||||
|
|
||||||
|
@Override
|
||||||
|
public void drop(DataBlock obj) {
|
||||||
|
if (obj.data.isAccessible()) {
|
||||||
|
obj.data.close();
|
||||||
|
}
|
||||||
|
delegate.drop(obj);
|
||||||
|
}
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
@ -22,16 +22,21 @@ import static org.warp.filesponge.FileSponge.BLOCK_SIZE;
|
|||||||
|
|
||||||
import io.netty.buffer.ByteBuf;
|
import io.netty.buffer.ByteBuf;
|
||||||
import io.netty.buffer.Unpooled;
|
import io.netty.buffer.Unpooled;
|
||||||
|
import io.netty.buffer.api.Buffer;
|
||||||
|
import io.netty.buffer.api.CompositeBuffer;
|
||||||
|
import io.netty.buffer.api.Send;
|
||||||
import io.netty.util.ReferenceCounted;
|
import io.netty.util.ReferenceCounted;
|
||||||
import it.cavallium.dbengine.database.Column;
|
import it.cavallium.dbengine.database.Column;
|
||||||
import it.cavallium.dbengine.database.LLDatabaseConnection;
|
import it.cavallium.dbengine.database.LLDatabaseConnection;
|
||||||
import it.cavallium.dbengine.database.LLDictionary;
|
import it.cavallium.dbengine.database.LLDictionary;
|
||||||
import it.cavallium.dbengine.database.LLDictionaryResultType;
|
import it.cavallium.dbengine.database.LLDictionaryResultType;
|
||||||
import it.cavallium.dbengine.database.LLKeyValueDatabase;
|
import it.cavallium.dbengine.database.LLKeyValueDatabase;
|
||||||
|
import it.cavallium.dbengine.database.LLUtils;
|
||||||
import it.cavallium.dbengine.database.UpdateMode;
|
import it.cavallium.dbengine.database.UpdateMode;
|
||||||
import it.cavallium.dbengine.database.UpdateReturnMode;
|
import it.cavallium.dbengine.database.UpdateReturnMode;
|
||||||
import it.cavallium.dbengine.client.DatabaseOptions;
|
import it.cavallium.dbengine.client.DatabaseOptions;
|
||||||
import it.cavallium.dbengine.database.serialization.SerializationException;
|
import it.cavallium.dbengine.database.serialization.SerializationException;
|
||||||
|
import it.cavallium.dbengine.database.serialization.Serializer.DeserializationResult;
|
||||||
import it.unimi.dsi.fastutil.booleans.BooleanArrayList;
|
import it.unimi.dsi.fastutil.booleans.BooleanArrayList;
|
||||||
import java.util.List;
|
import java.util.List;
|
||||||
import java.util.Objects;
|
import java.util.Objects;
|
||||||
@ -77,7 +82,7 @@ public class DiskCache implements URLsDiskHandler, URLsWriter {
|
|||||||
|
|
||||||
@Override
|
@Override
|
||||||
public Mono<Void> writeMetadata(URL url, Metadata metadata) {
|
public Mono<Void> writeMetadata(URL url, Metadata metadata) {
|
||||||
Mono<ByteBuf> keyMono = Mono.fromCallable(() -> url.getSerializer(db.getAllocator()).serialize(url));
|
Mono<Send<Buffer>> keyMono = Mono.fromCallable(() -> url.getSerializer(db.getAllocator()).serialize(url));
|
||||||
return fileMetadata
|
return fileMetadata
|
||||||
.update(keyMono, oldValue -> Objects.requireNonNullElseGet(oldValue,
|
.update(keyMono, oldValue -> Objects.requireNonNullElseGet(oldValue,
|
||||||
() -> diskMetadataSerializer.serialize(new DiskMetadata(metadata.size(),
|
() -> diskMetadataSerializer.serialize(new DiskMetadata(metadata.size(),
|
||||||
@ -89,22 +94,23 @@ public class DiskCache implements URLsDiskHandler, URLsWriter {
|
|||||||
|
|
||||||
@Override
|
@Override
|
||||||
public Mono<Void> writeContentBlock(URL url, DataBlock dataBlock) {
|
public Mono<Void> writeContentBlock(URL url, DataBlock dataBlock) {
|
||||||
Mono<ByteBuf> urlKeyMono = Mono.fromCallable(() -> url.getSerializer(db.getAllocator()).serialize(url));
|
Mono<Send<Buffer>> urlKeyMono = Mono.fromCallable(() -> url.getSerializer(db.getAllocator()).serialize(url));
|
||||||
Mono<ByteBuf> blockKeyMono = Mono.fromCallable(() -> getBlockKey(url, dataBlock.getId()));
|
Mono<Send<Buffer>> blockKeyMono = Mono.fromCallable(() -> getBlockKey(url, dataBlock.getId()));
|
||||||
return Mono
|
return Mono
|
||||||
.fromCallable(dataBlock::getData)
|
.fromCallable(dataBlock::getData)
|
||||||
.subscribeOn(Schedulers.boundedElastic())
|
.subscribeOn(Schedulers.boundedElastic())
|
||||||
.flatMap(bytes -> {
|
.flatMap(bytes_ -> Mono.using(
|
||||||
Mono<ByteBuf> bytesMono = Mono.just(bytes).map(ByteBuf::retain);
|
() -> bytes_,
|
||||||
return fileContent
|
bytes -> fileContent
|
||||||
.put(blockKeyMono, bytesMono, LLDictionaryResultType.VOID)
|
.put(blockKeyMono, Mono.just(bytes), LLDictionaryResultType.VOID)
|
||||||
.doOnNext(ReferenceCounted::release)
|
.doOnNext(Send::close)
|
||||||
.then();
|
.then(),
|
||||||
})
|
Send::close
|
||||||
|
))
|
||||||
.then(fileMetadata.update(urlKeyMono, prevBytes -> {
|
.then(fileMetadata.update(urlKeyMono, prevBytes -> {
|
||||||
@Nullable DiskMetadata result;
|
@Nullable DiskMetadata result;
|
||||||
if (prevBytes != null) {
|
if (prevBytes != null) {
|
||||||
DiskMetadata prevMeta = diskMetadataSerializer.deserialize(prevBytes);
|
DiskMetadata prevMeta = diskMetadataSerializer.deserialize(prevBytes).deserializedData();
|
||||||
if (!prevMeta.isDownloadedBlock(dataBlock.getId())) {
|
if (!prevMeta.isDownloadedBlock(dataBlock.getId())) {
|
||||||
BooleanArrayList bal = prevMeta.downloadedBlocks().clone();
|
BooleanArrayList bal = prevMeta.downloadedBlocks().clone();
|
||||||
if (prevMeta.size() == -1) {
|
if (prevMeta.size() == -1) {
|
||||||
@ -152,11 +158,11 @@ public class DiskCache implements URLsDiskHandler, URLsWriter {
|
|||||||
if (!downloaded) {
|
if (!downloaded) {
|
||||||
return Mono.empty();
|
return Mono.empty();
|
||||||
}
|
}
|
||||||
Mono<ByteBuf> blockKeyMono = Mono.fromCallable(() -> getBlockKey(url, blockId));
|
var blockKeyMono = Mono.fromCallable(() -> getBlockKey(url, blockId));
|
||||||
return fileContent
|
return fileContent
|
||||||
.get(null, blockKeyMono)
|
.get(null, blockKeyMono)
|
||||||
.map(data -> {
|
.map(dataToReceive -> {
|
||||||
try {
|
try (var data = dataToReceive.receive()) {
|
||||||
int blockOffset = getBlockOffset(blockId);
|
int blockOffset = getBlockOffset(blockId);
|
||||||
int blockLength = data.readableBytes();
|
int blockLength = data.readableBytes();
|
||||||
if (meta.size() != -1) {
|
if (meta.size() != -1) {
|
||||||
@ -169,20 +175,19 @@ public class DiskCache implements URLsDiskHandler, URLsWriter {
|
|||||||
assert data.readableBytes() == BLOCK_SIZE;
|
assert data.readableBytes() == BLOCK_SIZE;
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
return new DataBlock(blockOffset, blockLength, data.retain());
|
return DataBlock.of(blockOffset, blockLength, data.send());
|
||||||
} finally {
|
|
||||||
data.release();
|
|
||||||
}
|
}
|
||||||
});
|
});
|
||||||
})
|
})
|
||||||
);
|
);
|
||||||
}
|
}
|
||||||
|
|
||||||
private ByteBuf getBlockKey(URL url, int blockId) throws SerializationException {
|
private Send<Buffer> getBlockKey(URL url, int blockId) throws SerializationException {
|
||||||
ByteBuf urlBytes = url.getSerializer(db.getAllocator()).serialize(url);
|
try (var urlBytes = url.getSerializer(db.getAllocator()).serialize(url).receive()) {
|
||||||
ByteBuf blockIdBytes = this.db.getAllocator().directBuffer(Integer.BYTES, Integer.BYTES);
|
Buffer blockIdBytes = this.db.getAllocator().allocate(Integer.BYTES);
|
||||||
blockIdBytes.writeInt(blockId);
|
blockIdBytes.writeInt(blockId);
|
||||||
return Unpooled.wrappedBuffer(urlBytes, blockIdBytes);
|
return LLUtils.compositeBuffer(db.getAllocator(), urlBytes.send(), blockIdBytes.send());
|
||||||
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
private static int getBlockOffset(int blockId) {
|
private static int getBlockOffset(int blockId) {
|
||||||
@ -191,10 +196,11 @@ public class DiskCache implements URLsDiskHandler, URLsWriter {
|
|||||||
|
|
||||||
@Override
|
@Override
|
||||||
public Mono<DiskMetadata> requestDiskMetadata(URL url) {
|
public Mono<DiskMetadata> requestDiskMetadata(URL url) {
|
||||||
Mono<ByteBuf> urlKeyMono = Mono.fromCallable(() -> url.getSerializer(db.getAllocator()).serialize(url));
|
Mono<Send<Buffer>> urlKeyMono = Mono.fromCallable(() -> url.getSerializer(db.getAllocator()).serialize(url));
|
||||||
return fileMetadata
|
return fileMetadata
|
||||||
.get(null, urlKeyMono)
|
.get(null, urlKeyMono)
|
||||||
.map(diskMetadataSerializer::deserialize);
|
.map(diskMetadataSerializer::deserialize)
|
||||||
|
.map(DeserializationResult::deserializedData);
|
||||||
}
|
}
|
||||||
|
|
||||||
@Override
|
@Override
|
||||||
@ -205,14 +211,15 @@ public class DiskCache implements URLsDiskHandler, URLsWriter {
|
|||||||
|
|
||||||
@Override
|
@Override
|
||||||
public Mono<Tuple2<Metadata, Flux<DataBlock>>> request(URL url) {
|
public Mono<Tuple2<Metadata, Flux<DataBlock>>> request(URL url) {
|
||||||
Mono<ByteBuf> urlKeyMono = Mono.fromCallable(() -> url.getSerializer(db.getAllocator()).serialize(url));
|
Mono<Send<Buffer>> urlKeyMono = Mono.fromCallable(() -> url.getSerializer(db.getAllocator()).serialize(url));
|
||||||
return Mono
|
return Mono
|
||||||
.using(
|
.using(
|
||||||
() -> url.getSerializer(db.getAllocator()).serialize(url),
|
() -> url.getSerializer(db.getAllocator()).serialize(url),
|
||||||
key -> fileMetadata.get(null, urlKeyMono),
|
key -> fileMetadata.get(null, urlKeyMono),
|
||||||
ReferenceCounted::release
|
Send::close
|
||||||
)
|
)
|
||||||
.map(diskMetadataSerializer::deserialize)
|
.map(diskMetadataSerializer::deserialize)
|
||||||
|
.map(DeserializationResult::deserializedData)
|
||||||
.map(diskMeta -> {
|
.map(diskMeta -> {
|
||||||
var meta = diskMeta.asMetadata();
|
var meta = diskMeta.asMetadata();
|
||||||
if (diskMeta.isDownloadedFully()) {
|
if (diskMeta.isDownloadedFully()) {
|
||||||
|
@ -23,6 +23,11 @@ import io.netty.buffer.ByteBufAllocator;
|
|||||||
import io.netty.buffer.ByteBufInputStream;
|
import io.netty.buffer.ByteBufInputStream;
|
||||||
import io.netty.buffer.ByteBufOutputStream;
|
import io.netty.buffer.ByteBufOutputStream;
|
||||||
import io.netty.buffer.PooledByteBufAllocator;
|
import io.netty.buffer.PooledByteBufAllocator;
|
||||||
|
import io.netty.buffer.api.Buffer;
|
||||||
|
import io.netty.buffer.api.BufferAllocator;
|
||||||
|
import io.netty.buffer.api.Send;
|
||||||
|
import it.cavallium.dbengine.database.serialization.BufferDataInput;
|
||||||
|
import it.cavallium.dbengine.database.serialization.BufferDataOutput;
|
||||||
import it.cavallium.dbengine.database.serialization.Serializer;
|
import it.cavallium.dbengine.database.serialization.Serializer;
|
||||||
import it.unimi.dsi.fastutil.booleans.BooleanArrayList;
|
import it.unimi.dsi.fastutil.booleans.BooleanArrayList;
|
||||||
import java.io.ByteArrayInputStream;
|
import java.io.ByteArrayInputStream;
|
||||||
@ -80,19 +85,17 @@ public record DiskMetadata(int size, BooleanArrayList downloadedBlocks) {
|
|||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
public static class DiskMetadataSerializer implements Serializer<DiskMetadata, ByteBuf> {
|
public static class DiskMetadataSerializer implements Serializer<DiskMetadata> {
|
||||||
|
|
||||||
private final ByteBufAllocator allocator;
|
private final BufferAllocator allocator;
|
||||||
|
|
||||||
public DiskMetadataSerializer(ByteBufAllocator allocator) {
|
public DiskMetadataSerializer(BufferAllocator allocator) {
|
||||||
this.allocator = allocator;
|
this.allocator = allocator;
|
||||||
}
|
}
|
||||||
|
|
||||||
@Override
|
@Override
|
||||||
public @NotNull DiskMetadata deserialize(@NotNull ByteBuf serialized) {
|
public @NotNull DeserializationResult<DiskMetadata> deserialize(@NotNull Send<Buffer> serialized) {
|
||||||
try {
|
var dis = new BufferDataInput(serialized);
|
||||||
var bais = new ByteBufInputStream(serialized);
|
|
||||||
var dis = new DataInputStream(bais);
|
|
||||||
int size = dis.readInt();
|
int size = dis.readInt();
|
||||||
int blocksCount;
|
int blocksCount;
|
||||||
if (size == -1) {
|
if (size == -1) {
|
||||||
@ -104,19 +107,13 @@ public record DiskMetadata(int size, BooleanArrayList downloadedBlocks) {
|
|||||||
for (int i = 0; i < blocksCount; i++) {
|
for (int i = 0; i < blocksCount; i++) {
|
||||||
downloadedBlocks.add(dis.readBoolean());
|
downloadedBlocks.add(dis.readBoolean());
|
||||||
}
|
}
|
||||||
return new DiskMetadata(size, downloadedBlocks);
|
return new DeserializationResult<>(new DiskMetadata(size, downloadedBlocks), dis.getReadBytesCount());
|
||||||
} catch (IOException e) {
|
|
||||||
throw new SerializationException(e);
|
|
||||||
} finally {
|
|
||||||
serialized.release();
|
|
||||||
}
|
|
||||||
}
|
}
|
||||||
|
|
||||||
@Override
|
@Override
|
||||||
public @NotNull ByteBuf serialize(@NotNull DiskMetadata deserialized) {
|
public @NotNull Send<Buffer> serialize(@NotNull DiskMetadata deserialized) {
|
||||||
ByteBuf buffer = allocator.buffer();
|
try (var buffer = allocator.allocate(64)) {
|
||||||
try (var bos = new ByteBufOutputStream(buffer)) {
|
var dos = new BufferDataOutput(buffer);
|
||||||
try (var dos = new DataOutputStream(bos)) {
|
|
||||||
dos.writeInt(deserialized.size());
|
dos.writeInt(deserialized.size());
|
||||||
if (deserialized.size == -1) {
|
if (deserialized.size == -1) {
|
||||||
dos.writeShort(deserialized.getBlocksCount());
|
dos.writeShort(deserialized.getBlocksCount());
|
||||||
@ -126,10 +123,7 @@ public record DiskMetadata(int size, BooleanArrayList downloadedBlocks) {
|
|||||||
for (boolean downloadedBlock : deserialized.downloadedBlocks()) {
|
for (boolean downloadedBlock : deserialized.downloadedBlocks()) {
|
||||||
dos.writeBoolean(downloadedBlock);
|
dos.writeBoolean(downloadedBlock);
|
||||||
}
|
}
|
||||||
}
|
return buffer.send();
|
||||||
return buffer;
|
|
||||||
} catch (IOException e) {
|
|
||||||
throw new SerializationException(e);
|
|
||||||
}
|
}
|
||||||
}
|
}
|
||||||
|
|
||||||
|
@ -101,7 +101,7 @@ public class FileSponge implements URLsHandler {
|
|||||||
)
|
)
|
||||||
.distinct(DataBlock::getId)
|
.distinct(DataBlock::getId)
|
||||||
|
|
||||||
.doOnDiscard(DataBlock.class, DataBlock::release);
|
.doOnDiscard(DataBlock.class, DataBlock::close);
|
||||||
}
|
}
|
||||||
|
|
||||||
@Override
|
@Override
|
||||||
|
@ -20,10 +20,11 @@ package org.warp.filesponge;
|
|||||||
|
|
||||||
import io.netty.buffer.ByteBuf;
|
import io.netty.buffer.ByteBuf;
|
||||||
import io.netty.buffer.ByteBufAllocator;
|
import io.netty.buffer.ByteBufAllocator;
|
||||||
|
import io.netty.buffer.api.BufferAllocator;
|
||||||
import it.cavallium.dbengine.database.serialization.Serializer;
|
import it.cavallium.dbengine.database.serialization.Serializer;
|
||||||
|
|
||||||
public interface URL {
|
public interface URL {
|
||||||
|
|
||||||
Serializer<URL, ByteBuf> getSerializer(ByteBufAllocator allocator);
|
Serializer<URL> getSerializer(BufferAllocator allocator);
|
||||||
|
|
||||||
}
|
}
|
||||||
|
Loading…
Reference in New Issue
Block a user