123456789101112131415161718192021222324252627282930313233343536373839404142434445464748495051525354555657585960616263646566676869707172737475767778798081828384858687888990919293949596979899100101102103104105106107108109110111112113114115116117118119120121122123124125126127128129130131132133134135136137138139140141142143144145146147148149150151152153154155156157158159160161162163164165166167168169170171172173174175176177178179180181182183184185186187188189190191192193194195196197198199200201202203204205206207208209210211212213214215216217218219220221222223224225226227228229230231232233234235236237238239240241242243244245246247248249250251252253254255256257258259260261262263264265266267268269270271272273274275276277278279280281282283284285286287288289290291292293294295296297298299300301302303304305306307308309310311312313314315316317318319320321322323324325326327328329330331332333334335336337338339340341342343344345346347348349350351352353354355356357358359360361362363364365366367368369370371372373374375376377378379380381382383384385386387388389390391392393394395396397398399400401402403404405406407408409410411412413414415416417418419420421422423424425426427428429 |
- /**
- * 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.
- */
- #include "hdfspp/hdfspp.h"
- #include "fs/filesystem.h"
- #include "common/hdfs_configuration.h"
- #include "common/configuration_loader.h"
- #include <hdfs/hdfs.h>
- #include <hdfspp/hdfs_ext.h>
- #include <string>
- #include <cstring>
- #include <iostream>
- #include <algorithm>
- using namespace hdfs;
- /* Separate the handles used by the C api from the C++ API*/
- struct hdfs_internal {
- hdfs_internal(FileSystem *p) : filesystem_(p) {}
- hdfs_internal(std::unique_ptr<FileSystem> p)
- : filesystem_(std::move(p)) {}
- virtual ~hdfs_internal(){};
- FileSystem *get_impl() { return filesystem_.get(); }
- const FileSystem *get_impl() const { return filesystem_.get(); }
- private:
- std::unique_ptr<FileSystem> filesystem_;
- };
- struct hdfsFile_internal {
- hdfsFile_internal(FileHandle *p) : file_(p) {}
- hdfsFile_internal(std::unique_ptr<FileHandle> p) : file_(std::move(p)) {}
- virtual ~hdfsFile_internal(){};
- FileHandle *get_impl() { return file_.get(); }
- const FileHandle *get_impl() const { return file_.get(); }
- private:
- std::unique_ptr<FileHandle> file_;
- };
- /* Keep thread local copy of last error string */
- thread_local std::string errstr;
- /* Fetch last error that happened in this thread */
- void hdfsGetLastError(char *buf, int len) {
- if(nullptr == buf || len < 1 || errstr.empty()) {
- return;
- }
- /* leave space for a trailing null */
- size_t copylen = std::min((size_t)errstr.size(), (size_t)len);
- if(copylen == (size_t)len) {
- copylen--;
- }
- strncpy(buf, errstr.c_str(), copylen);
- /* stick in null */
- buf[copylen] = 0;
- }
- struct hdfsBuilder {
- hdfsBuilder();
- hdfsBuilder(const char * directory);
- virtual ~hdfsBuilder() {}
- ConfigurationLoader loader;
- HdfsConfiguration config;
- std::string overrideHost;
- tPort overridePort; // 0 --> use default
- static constexpr tPort kUseDefaultPort = 0;
- static constexpr tPort kDefaultPort = 8020;
- };
- /* Error handling with optional debug to stderr */
- static void ReportError(int errnum, std::string msg) {
- errno = errnum;
- errstr = msg;
- #ifdef LIBHDFSPP_C_API_ENABLE_DEBUG
- std::cerr << "Error: errno=" << strerror(errnum) << " message=\"" << msg
- << "\"" << std::endl;
- #else
- (void)msg;
- #endif
- }
- /* Convert Status wrapped error into appropriate errno and return code */
- static int Error(const Status &stat) {
- int code = stat.code();
- switch (code) {
- case Status::Code::kOk:
- return 0;
- case Status::Code::kInvalidArgument:
- ReportError(EINVAL, "Invalid argument");
- break;
- case Status::Code::kResourceUnavailable:
- ReportError(EAGAIN, "Resource temporarily unavailable");
- break;
- case Status::Code::kUnimplemented:
- ReportError(ENOSYS, "Function not implemented");
- break;
- case Status::Code::kException:
- ReportError(EINTR, "Exception raised");
- break;
- case Status::Code::kOperationCanceled:
- ReportError(EINTR, "Operation canceled");
- break;
- default:
- ReportError(ENOSYS, "Error: unrecognised code");
- }
- return -1;
- }
- /* return false on failure */
- bool CheckSystemAndHandle(hdfsFS fs, hdfsFile file) {
- if (!fs) {
- ReportError(ENODEV, "Cannot perform FS operations with null FS handle.");
- return false;
- }
- if (!file) {
- ReportError(EBADF, "Cannot perform FS operations with null File handle.");
- return false;
- }
- return true;
- }
- /**
- * C API implementations
- **/
- int hdfsFileIsOpenForRead(hdfsFile file) {
- /* files can only be open for reads at the moment, do a quick check */
- if (file) {
- return 1; // Update implementation when we get file writing
- }
- return 0;
- }
- hdfsFS hdfsConnect(const char *nn, tPort port) {
- std::string port_as_string = std::to_string(port);
- IoService * io_service = IoService::New();
- FileSystem *fs = FileSystem::New(io_service, Options());
- if (!fs) {
- return nullptr;
- }
- if (!fs->Connect(nn, port_as_string).ok()) {
- ReportError(ENODEV, "Unable to connect to NameNode.");
- // FileSystem's ctor might take ownership of the io_service; if it does,
- // it will null out the pointer
- if (io_service)
- delete io_service;
- delete fs;
- return nullptr;
- }
- return new hdfs_internal(fs);
- }
- int hdfsDisconnect(hdfsFS fs) {
- if (!fs) {
- ReportError(ENODEV, "Cannot disconnect null FS handle.");
- return -1;
- }
- delete fs;
- return 0;
- }
- hdfsFile hdfsOpenFile(hdfsFS fs, const char *path, int flags, int bufferSize,
- short replication, tSize blocksize) {
- (void)flags;
- (void)bufferSize;
- (void)replication;
- (void)blocksize;
- if (!fs) {
- ReportError(ENODEV, "Cannot perform FS operations with null FS handle.");
- return nullptr;
- }
- FileHandle *f = nullptr;
- Status stat = fs->get_impl()->Open(path, &f);
- if (!stat.ok()) {
- return nullptr;
- }
- return new hdfsFile_internal(f);
- }
- int hdfsCloseFile(hdfsFS fs, hdfsFile file) {
- if (!CheckSystemAndHandle(fs, file)) {
- return -1;
- }
- delete file;
- return 0;
- }
- tSize hdfsPread(hdfsFS fs, hdfsFile file, tOffset position, void *buffer,
- tSize length) {
- if (!CheckSystemAndHandle(fs, file)) {
- return -1;
- }
- size_t len = length;
- Status stat = file->get_impl()->PositionRead(buffer, &len, position);
- if(!stat.ok()) {
- return Error(stat);
- }
- return (tSize)len;
- }
- tSize hdfsRead(hdfsFS fs, hdfsFile file, void *buffer, tSize length) {
- if (!CheckSystemAndHandle(fs, file)) {
- return -1;
- }
- size_t len = length;
- Status stat = file->get_impl()->Read(buffer, &len);
- if (!stat.ok()) {
- return Error(stat);
- }
- return (tSize)len;
- }
- /* 0 on success, -1 on error*/
- int hdfsSeek(hdfsFS fs, hdfsFile file, tOffset desiredPos) {
- if (!CheckSystemAndHandle(fs, file)) {
- return -1;
- }
- off_t desired = desiredPos;
- Status stat = file->get_impl()->Seek(&desired, std::ios_base::beg);
- if (!stat.ok()) {
- return Error(stat);
- }
- return 0;
- }
- tOffset hdfsTell(hdfsFS fs, hdfsFile file) {
- if (!CheckSystemAndHandle(fs, file)) {
- return -1;
- }
- ssize_t offset = 0;
- Status stat = file->get_impl()->Seek(&offset, std::ios_base::cur);
- if (!stat.ok()) {
- return Error(stat);
- }
- return offset;
- }
- /* extended API */
- int hdfsCancel(hdfsFS fs, hdfsFile file) {
- if (!CheckSystemAndHandle(fs, file)) {
- return -1;
- }
- static_cast<FileHandleImpl*>(file->get_impl())->CancelOperations();
- return 0;
- }
- /*******************************************************************
- * BUILDER INTERFACE
- *******************************************************************/
- HdfsConfiguration LoadDefault(ConfigurationLoader & loader)
- {
- optional<HdfsConfiguration> result = loader.LoadDefaultResources<HdfsConfiguration>();
- if (result)
- {
- return result.value();
- }
- else
- {
- return loader.New<HdfsConfiguration>();
- }
- }
- hdfsBuilder::hdfsBuilder() : config(LoadDefault(loader)), overridePort(kUseDefaultPort)
- {
- }
- hdfsBuilder::hdfsBuilder(const char * directory) :
- config(loader.New<HdfsConfiguration>()), overridePort(kUseDefaultPort)
- {
- loader.SetSearchPath(directory);
- config = LoadDefault(loader);
- }
- struct hdfsBuilder *hdfsNewBuilder(void)
- {
- return new struct hdfsBuilder();
- }
- void hdfsBuilderSetNameNode(struct hdfsBuilder *bld, const char *nn)
- {
- bld->overrideHost = nn;
- }
- void hdfsBuilderSetNameNodePort(struct hdfsBuilder *bld, tPort port)
- {
- bld->overridePort = port;
- }
- void hdfsFreeBuilder(struct hdfsBuilder *bld)
- {
- delete bld;
- }
- int hdfsBuilderConfSetStr(struct hdfsBuilder *bld, const char *key,
- const char *val)
- {
- optional<HdfsConfiguration> newConfig = bld->loader.OverlayValue(bld->config, key, val);
- if (newConfig)
- {
- bld->config = newConfig.value();
- return 0;
- }
- else
- {
- return 1;
- }
- }
- void hdfsConfStrFree(char *val)
- {
- free(val);
- }
- hdfsFS hdfsBuilderConnect(struct hdfsBuilder *bld) {
- if (!bld->overrideHost.empty())
- {
- // TODO: pass rest of config once we get that done (HDFS-9556)
- tPort port = bld->overridePort;
- if (port == hdfsBuilder::kUseDefaultPort)
- {
- port = hdfsBuilder::kDefaultPort;
- }
- return hdfsConnect(bld->overrideHost.c_str(), port);
- }
- else
- {
- //TODO: allow construction from default port once that is done (HDFS-9556)
- ReportError(EINVAL, "No host provided to builder in hdfsBuilderConnect");
- return nullptr;
- }
- }
- int hdfsConfGetStr(const char *key, char **val)
- {
- hdfsBuilder builder;
- return hdfsBuilderConfGetStr(&builder, key, val);
- }
- int hdfsConfGetInt(const char *key, int32_t *val)
- {
- hdfsBuilder builder;
- return hdfsBuilderConfGetInt(&builder, key, val);
- }
- //
- // Extended builder interface
- //
- struct hdfsBuilder *hdfsNewBuilderFromDirectory(const char * configDirectory)
- {
- return new struct hdfsBuilder(configDirectory);
- }
- int hdfsBuilderConfGetStr(struct hdfsBuilder *bld, const char *key,
- char **val)
- {
- optional<std::string> value = bld->config.Get(key);
- if (value)
- {
- size_t len = value->length() + 1;
- *val = static_cast<char *>(malloc(len));
- strncpy(*val, value->c_str(), len);
- }
- else
- {
- *val = nullptr;
- }
- return 0;
- }
- // If we're running on a 32-bit platform, we might get 64-bit values that
- // don't fit in an int, and int is specified by the java hdfs.h interface
- bool isValidInt(int64_t value)
- {
- return (value >= std::numeric_limits<int>::min() &&
- value <= std::numeric_limits<int>::max());
- }
- int hdfsBuilderConfGetInt(struct hdfsBuilder *bld, const char *key, int32_t *val)
- {
- // Pull from default configuration
- optional<int64_t> value = bld->config.GetInt(key);
- if (value)
- {
- if (!isValidInt(*value))
- return 1;
- *val = *value;
- }
- // If not found, don't change val
- return 0;
- }
|