Search in sources :

Example 1 with BaseKVStoreClosure

use of io.dingodb.store.row.storage.BaseKVStoreClosure in project dingo by dingodb.

the class DefaultRegionKVService method handleMergeRequest.

@Override
public void handleMergeRequest(final MergeRequest request, final RequestProcessClosure<BaseRequest, BaseResponse<?>> closure) {
    final MergeResponse response = new MergeResponse();
    response.setRegionId(getRegionId());
    response.setRegionEpoch(getRegionEpoch());
    try {
        KVParameterRequires.requireSameEpoch(request, getRegionEpoch());
        final byte[] key = KVParameterRequires.requireNonNull(request.getKey(), "merge.key");
        final byte[] value = KVParameterRequires.requireNonNull(request.getValue(), "merge.value");
        this.rawKVStore.merge(key, value, new BaseKVStoreClosure() {

            @Override
            public void run(final Status status) {
                if (status.isOk()) {
                    response.setValue((Boolean) getData());
                } else {
                    setFailure(request, response, status, getError());
                }
                closure.sendResponse(response);
            }
        });
    } catch (final Throwable t) {
        LOG.error("Failed to handle: {}, {}.", request, StackTraceUtil.stackTrace(t));
        response.setError(Errors.forException(t));
        closure.sendResponse(response);
    }
}
Also used : Status(io.dingodb.raft.Status) BaseKVStoreClosure(io.dingodb.store.row.storage.BaseKVStoreClosure) MergeResponse(io.dingodb.store.row.cmd.store.MergeResponse)

Example 2 with BaseKVStoreClosure

use of io.dingodb.store.row.storage.BaseKVStoreClosure in project dingo by dingodb.

the class DefaultRegionKVService method handlePutRequest.

@Override
public void handlePutRequest(final PutRequest request, final RequestProcessClosure<BaseRequest, BaseResponse<?>> closure) {
    final PutResponse response = new PutResponse();
    response.setRegionId(getRegionId());
    response.setRegionEpoch(getRegionEpoch());
    try {
        KVParameterRequires.requireSameEpoch(request, getRegionEpoch());
        final byte[] key = KVParameterRequires.requireNonNull(request.getKey(), "put.key");
        final byte[] value = KVParameterRequires.requireNonNull(request.getValue(), "put.value");
        this.rawKVStore.put(key, value, new BaseKVStoreClosure() {

            @Override
            public void run(final Status status) {
                if (status.isOk()) {
                    response.setValue((Boolean) getData());
                } else {
                    setFailure(request, response, status, getError());
                }
                closure.sendResponse(response);
            }
        });
    } catch (final Throwable t) {
        LOG.error("Failed to handle: {}, {}.", request, StackTraceUtil.stackTrace(t));
        response.setError(Errors.forException(t));
        closure.sendResponse(response);
    }
}
Also used : Status(io.dingodb.raft.Status) BaseKVStoreClosure(io.dingodb.store.row.storage.BaseKVStoreClosure) PutResponse(io.dingodb.store.row.cmd.store.PutResponse) BatchPutResponse(io.dingodb.store.row.cmd.store.BatchPutResponse) GetAndPutResponse(io.dingodb.store.row.cmd.store.GetAndPutResponse) CompareAndPutResponse(io.dingodb.store.row.cmd.store.CompareAndPutResponse)

Example 3 with BaseKVStoreClosure

use of io.dingodb.store.row.storage.BaseKVStoreClosure in project dingo by dingodb.

the class DefaultRegionKVService method handleMultiGetRequest.

@Override
public void handleMultiGetRequest(final MultiGetRequest request, final RequestProcessClosure<BaseRequest, BaseResponse<?>> closure) {
    final MultiGetResponse response = new MultiGetResponse();
    response.setRegionId(getRegionId());
    response.setRegionEpoch(getRegionEpoch());
    try {
        KVParameterRequires.requireSameEpoch(request, getRegionEpoch());
        final List<byte[]> keys = KVParameterRequires.requireNonEmpty(request.getKeys(), "multiGet.keys");
        this.rawKVStore.multiGet(keys, request.isReadOnlySafe(), new BaseKVStoreClosure() {

            @SuppressWarnings("unchecked")
            @Override
            public void run(final Status status) {
                if (status.isOk()) {
                    response.setValue((Map<ByteArray, byte[]>) getData());
                } else {
                    setFailure(request, response, status, getError());
                }
                closure.sendResponse(response);
            }
        });
    } catch (final Throwable t) {
        LOG.error("Failed to handle: {}, {}.", request, StackTraceUtil.stackTrace(t));
        response.setError(Errors.forException(t));
        closure.sendResponse(response);
    }
}
Also used : Status(io.dingodb.raft.Status) MultiGetResponse(io.dingodb.store.row.cmd.store.MultiGetResponse) BaseKVStoreClosure(io.dingodb.store.row.storage.BaseKVStoreClosure) Map(java.util.Map)

Example 4 with BaseKVStoreClosure

use of io.dingodb.store.row.storage.BaseKVStoreClosure in project dingo by dingodb.

the class DefaultRegionKVService method handleNodeExecuteRequest.

@Override
public void handleNodeExecuteRequest(final NodeExecuteRequest request, final RequestProcessClosure<BaseRequest, BaseResponse<?>> closure) {
    final NodeExecuteResponse response = new NodeExecuteResponse();
    response.setRegionId(getRegionId());
    response.setRegionEpoch(getRegionEpoch());
    try {
        KVParameterRequires.requireSameEpoch(request, getRegionEpoch());
        final NodeExecutor executor = KVParameterRequires.requireNonNull(request.getNodeExecutor(), "node.executor");
        this.rawKVStore.execute(executor, true, new BaseKVStoreClosure() {

            @Override
            public void run(final Status status) {
                if (status.isOk()) {
                    response.setValue((Boolean) getData());
                } else {
                    setFailure(request, response, status, getError());
                }
                closure.sendResponse(response);
            }
        });
    } catch (final Throwable t) {
        LOG.error("Failed to handle: {}, {}.", request, StackTraceUtil.stackTrace(t));
        response.setError(Errors.forException(t));
        closure.sendResponse(response);
    }
}
Also used : Status(io.dingodb.raft.Status) BaseKVStoreClosure(io.dingodb.store.row.storage.BaseKVStoreClosure) NodeExecuteResponse(io.dingodb.store.row.cmd.store.NodeExecuteResponse) NodeExecutor(io.dingodb.store.row.storage.NodeExecutor)

Example 5 with BaseKVStoreClosure

use of io.dingodb.store.row.storage.BaseKVStoreClosure in project dingo by dingodb.

the class DefaultRegionKVService method handleRangeSplitRequest.

@Override
public void handleRangeSplitRequest(final RangeSplitRequest request, final RequestProcessClosure<BaseRequest, BaseResponse<?>> closure) {
    final RangeSplitResponse response = new RangeSplitResponse();
    response.setRegionId(getRegionId());
    response.setRegionEpoch(getRegionEpoch());
    try {
        // do not need to check the region epoch
        final String newRegionId = KVParameterRequires.requireNonNull(request.getNewRegionId(), "rangeSplit.newRegionId");
        this.regionEngine.getStoreEngine().applySplit(request.getRegionId(), newRegionId, new BaseKVStoreClosure() {

            @Override
            public void run(final Status status) {
                if (status.isOk()) {
                    response.setValue((Boolean) getData());
                } else {
                    setFailure(request, response, status, getError());
                }
                closure.sendResponse(response);
            }
        });
    } catch (final Throwable t) {
        LOG.error("Failed to handle: {}, {}.", request, StackTraceUtil.stackTrace(t));
        response.setError(Errors.forException(t));
        closure.sendResponse(response);
    }
}
Also used : Status(io.dingodb.raft.Status) RangeSplitResponse(io.dingodb.store.row.cmd.store.RangeSplitResponse) BaseKVStoreClosure(io.dingodb.store.row.storage.BaseKVStoreClosure)

Aggregations

Status (io.dingodb.raft.Status)21 BaseKVStoreClosure (io.dingodb.store.row.storage.BaseKVStoreClosure)21 BatchDeleteResponse (io.dingodb.store.row.cmd.store.BatchDeleteResponse)2 BatchPutResponse (io.dingodb.store.row.cmd.store.BatchPutResponse)2 CompareAndPutResponse (io.dingodb.store.row.cmd.store.CompareAndPutResponse)2 GetAndPutResponse (io.dingodb.store.row.cmd.store.GetAndPutResponse)2 MultiGetResponse (io.dingodb.store.row.cmd.store.MultiGetResponse)2 KVEntry (io.dingodb.store.row.storage.KVEntry)2 DistributedLock (io.dingodb.store.row.util.concurrent.DistributedLock)2 RegionEngine (io.dingodb.store.row.RegionEngine)1 CASAllResponse (io.dingodb.store.row.cmd.store.CASAllResponse)1 ContainsKeyResponse (io.dingodb.store.row.cmd.store.ContainsKeyResponse)1 DeleteRangeResponse (io.dingodb.store.row.cmd.store.DeleteRangeResponse)1 DeleteResponse (io.dingodb.store.row.cmd.store.DeleteResponse)1 GetResponse (io.dingodb.store.row.cmd.store.GetResponse)1 GetSequenceResponse (io.dingodb.store.row.cmd.store.GetSequenceResponse)1 KeyLockResponse (io.dingodb.store.row.cmd.store.KeyLockResponse)1 KeyUnlockResponse (io.dingodb.store.row.cmd.store.KeyUnlockResponse)1 MergeResponse (io.dingodb.store.row.cmd.store.MergeResponse)1 NodeExecuteResponse (io.dingodb.store.row.cmd.store.NodeExecuteResponse)1