 Macaroons | |
  Authz | |
  Handler | |
 nlohmann | Namespace for Niels Lohmann |
  detail | Detail namespace with internal helper functions |
   container_input_adapter_factory_impl | |
    container_input_adapter_factory | |
    container_input_adapter_factory< ContainerType, void_t< decltype(begin(std::declval< ContainerType >()), end(std::declval< ContainerType >()))> > | |
   dtoa_impl | Implements the Grisu2 algorithm for binary to decimal floating-point conversion |
    diyfp | |
    boundaries | |
    cached_power | |
   utility_internal | |
    Extend | |
    Extend< integer_sequence< T, Ints...>, SeqSize, 0 > | |
    Extend< integer_sequence< T, Ints...>, SeqSize, 1 > | |
    Gen | |
    Gen< T, 0 > | |
   position_t | Struct to capture the start position of the current token |
   exception | General exception of the basic_json class |
   parse_error | Exception indicating a parse error |
   invalid_iterator | Exception indicating errors with iterators |
   type_error | Exception indicating executing a member function with a wrong type |
   out_of_range | Exception indicating access out of the defined range |
   other_error | Exception indicating other library errors |
   integer_sequence | |
   priority_tag | |
   priority_tag< 0 > | |
   static_const | |
   identity_tag | |
   make_void | |
   iterator_types | |
   iterator_types< It, void_t< typename It::difference_type, typename It::value_type, typename It::pointer, typename It::reference, typename It::iterator_category > > | |
   iterator_traits | |
   iterator_traits< T, enable_if_t< !std::is_pointer< T >::value > > | |
   iterator_traits< T *, enable_if_t< std::is_object< T >::value > > | |
   nonesuch | |
   detector | |
   detector< Default, void_t< Op< Args...> >, Op, Args...> | |
   is_detected_lazy | |
   is_basic_json | |
   is_basic_json< NLOHMANN_BASIC_JSON_TPL > | |
   json_ref | |
   is_json_ref | |
   is_json_ref< json_ref< T > > | |
   has_from_json | |
   is_getable | |
   has_from_json< BasicJsonType, T, enable_if_t< !is_basic_json< T >::value > > | |
   has_non_default_from_json | |
   has_non_default_from_json< BasicJsonType, T, enable_if_t< !is_basic_json< T >::value > > | |
   has_to_json | |
   has_to_json< BasicJsonType, T, enable_if_t< !is_basic_json< T >::value > > | |
   conjunction | |
   conjunction< B1 > | |
   conjunction< B1, Bn...> | |
   negation | |
   is_default_constructible | |
   is_default_constructible< std::pair< T1, T2 > > | |
   is_default_constructible< const std::pair< T1, T2 > > | |
   is_default_constructible< std::tuple< Ts...> > | |
   is_default_constructible< const std::tuple< Ts...> > | |
   is_constructible | |
   is_constructible< std::pair< T1, T2 > > | |
   is_constructible< const std::pair< T1, T2 > > | |
   is_constructible< std::tuple< Ts...> > | |
   is_constructible< const std::tuple< Ts...> > | |
   is_iterator_traits | |
   is_iterator_traits< iterator_traits< T > > | |
   is_complete_type | |
   is_complete_type< T, decltype(void(sizeof(T)))> | |
   is_compatible_object_type_impl | |
   is_compatible_object_type_impl< BasicJsonType, CompatibleObjectType, enable_if_t< is_detected< mapped_type_t, CompatibleObjectType >::value &&is_detected< key_type_t, CompatibleObjectType >::value > > | |
   is_compatible_object_type | |
   is_constructible_object_type_impl | |
   is_constructible_object_type_impl< BasicJsonType, ConstructibleObjectType, enable_if_t< is_detected< mapped_type_t, ConstructibleObjectType >::value &&is_detected< key_type_t, ConstructibleObjectType >::value > > | |
   is_constructible_object_type | |
   is_compatible_string_type_impl | |
   is_compatible_string_type_impl< BasicJsonType, CompatibleStringType, enable_if_t< is_detected_exact< typename BasicJsonType::string_t::value_type, value_type_t, CompatibleStringType >::value > > | |
   is_compatible_string_type | |
   is_constructible_string_type_impl | |
   is_constructible_string_type_impl< BasicJsonType, ConstructibleStringType, enable_if_t< is_detected_exact< typename BasicJsonType::string_t::value_type, value_type_t, ConstructibleStringType >::value > > | |
   is_constructible_string_type | |
   is_compatible_array_type_impl | |
   is_compatible_array_type_impl< BasicJsonType, CompatibleArrayType, enable_if_t< is_detected< value_type_t, CompatibleArrayType >::value &&is_detected< iterator_t, CompatibleArrayType >::value &&!is_iterator_traits< iterator_traits< CompatibleArrayType > >::value > > | |
   is_compatible_array_type | |
   is_constructible_array_type_impl | |
   is_constructible_array_type_impl< BasicJsonType, ConstructibleArrayType, enable_if_t< std::is_same< ConstructibleArrayType, typename BasicJsonType::value_type >::value > > | |
   is_constructible_array_type_impl< BasicJsonType, ConstructibleArrayType, enable_if_t< !std::is_same< ConstructibleArrayType, typename BasicJsonType::value_type >::value &&is_default_constructible< ConstructibleArrayType >::value &&(std::is_move_assignable< ConstructibleArrayType >::value||std::is_copy_assignable< ConstructibleArrayType >::value)&&is_detected< value_type_t, ConstructibleArrayType >::value &&is_detected< iterator_t, ConstructibleArrayType >::value &&is_complete_type< detected_t< value_type_t, ConstructibleArrayType > >::value > > | |
   is_constructible_array_type | |
   is_compatible_integer_type_impl | |
   is_compatible_integer_type_impl< RealIntegerType, CompatibleNumberIntegerType, enable_if_t< std::is_integral< RealIntegerType >::value &&std::is_integral< CompatibleNumberIntegerType >::value &&!std::is_same< bool, CompatibleNumberIntegerType >::value > > | |
   is_compatible_integer_type | |
   is_compatible_type_impl | |
   is_compatible_type_impl< BasicJsonType, CompatibleType, enable_if_t< is_complete_type< CompatibleType >::value > > | |
   is_compatible_type | |
   is_constructible_tuple | |
   is_constructible_tuple< T1, std::tuple< Args...> > | |
   is_ordered_map | |
    two | |
   from_json_fn | |
   iteration_proxy_value | |
   iteration_proxy | Proxy class for the items() function |
   external_constructor | |
   external_constructor< value_t::boolean > | |
   external_constructor< value_t::string > | |
   external_constructor< value_t::binary > | |
   external_constructor< value_t::number_float > | |
   external_constructor< value_t::number_unsigned > | |
   external_constructor< value_t::number_integer > | |
   external_constructor< value_t::array > | |
   external_constructor< value_t::object > | |
   to_json_fn | |
   file_input_adapter | |
   input_stream_adapter | |
   iterator_input_adapter | |
   wide_string_input_helper | |
   wide_string_input_helper< BaseInputAdapter, 4 > | |
   wide_string_input_helper< BaseInputAdapter, 2 > | |
   wide_string_input_adapter | |
   iterator_input_adapter_factory | |
   is_iterator_of_multibyte | |
   iterator_input_adapter_factory< IteratorType, enable_if_t< is_iterator_of_multibyte< IteratorType >::value > > | |
   span_input_adapter | |
   json_sax_dom_parser | SAX implementation to create a JSON value from SAX events |
   json_sax_dom_callback_parser | |
   json_sax_acceptor | |
   lexer_base | |
   lexer | Lexical analysis |
   is_sax | |
   is_sax_static_asserts | |
   binary_reader | Deserialization of CBOR, MessagePack, and UBJSON values |
   parser | Syntax analysis |
   primitive_iterator_t | |
   internal_iterator | Iterator value |
   iter_impl | Template for a bidirectional iterator for the basic_json class This class implements a both iterators (iterator and const_iterator) for the basic_json class |
   json_reverse_iterator | Template for a reverse iterator class |
   output_adapter_protocol | Abstract output adapter interface |
   output_vector_adapter | Output adapter for byte vectors |
   output_stream_adapter | Output adapter for output streams |
   output_string_adapter | Output adapter for basic_string |
   output_adapter | |
   binary_writer | Serialization to CBOR and MessagePack values |
   serializer | |
  adl_serializer | Default JSONSerializer template argument |
  basic_json | Class to store JSON values |
  json_pointer | JSON Pointer |
  ordered_map | |
  byte_container_with_subtype | Internal type for a backed binary type |
  json_sax | SAX interface |
 Posix | |
 std | |
  tuple_size<::nlohmann::detail::iteration_proxy_value< IteratorType > > | |
  tuple_element< N,::nlohmann::detail::iteration_proxy_value< IteratorType > > | |
  hash< nlohmann::json > | Hash value for JSON objects |
  less<::nlohmann::detail::value_t > | |
 TPC | |
  State | |
  Stream | |
   Entry | |
  CurlDeleter | |
  TPCHandler | |
   TPCLogRecord | |
 Xrd | |
 XrdCl | |
  AnyObject | |
   ConcreteHolder | |
   Holder | |
  sequence | |
  seq_gen | |
  seq_gen< I, Ns...> | |
  seq_gen< 0, Ns...> | |
  ArgBase | Base class for Arg |
   FutureValue | A helper class for holding future value |
   FwdValue | A helper class for holding forwarded value |
   PlainValue | A helper class for holding plain value |
   ValueHolder | Abstract class for holding a value |
  Arg | |
  Arg< std::string > | |
  AsyncHSReader | Utility class encapsulating reading hand-shake response logic |
  AsyncHSWriter | Utility class encapsulating writing hand-shake request logic |
  AsyncMsgReader | Utility class encapsulating reading response message logic |
  AsyncMsgWriter | Utility class encapsulating writing request logic |
  AsyncPageReader | Object for reading out data from the PgRead response |
   iovmax_t | Helper class for retrieving the maximum size of the I/O vector |
  AsyncSocketHandler | |
  Buffer | Binary blob representation |
  Channel | A communication channel between the client and the server |
  ChannelHandlerList | A helper for handling channel event handlers |
  CheckpointImpl | Checkpoint operation ( |
  ChkptWrtImpl | Checkpointed write operation ( |
  ChkptWrtVImpl | Checkpointed WriteV operation ( |
  CheckSumHelper | Check sum helper for stdio |
  CheckSumManager | Manage the checksum calc objects |
  ClassicCopyJob | |
  CopyJob | Copy job |
  CopyProgressHandler | Interface for copy progress notification |
  CopyProcess | Copy the data from one point to another |
  Ctx | Utility class for storing a pointer to operation context |
  DefaultEnv | |
  DlgEnv | |
  EcPgReadResponseHandler | |
  EcHandler | |
  EcPlugInFactory | Plugin factory |
  Env | |
  File | A file |
  FileOperation | |
  OpenImpl | Open operation ( |
   ExResp | |
  ReadImpl | Read operation ( |
  PgReadImpl | PgRead operation ( |
  ReadTrait | RdWithRsp: factory for creating ReadImpl/PgReadImpl objects |
  ReadTrait< ChunkInfo > | |
  ReadTrait< PageInfo > | |
  PgWriteImpl | PgWrite operation ( |
  CloseImpl | Close operation ( |
  StatImpl | Stat operation ( |
  WriteImpl | Write operation ( |
  SyncImpl | Sync operation ( |
  TruncateImpl | Truncate operation ( |
  VectorReadImpl | VectorRead operation ( |
  VectorWriteImpl | VectorWrite operation ( |
  WriteVImpl | WriteV operation ( |
  FcntlImpl | Fcntl operation ( |
  VisaImpl | Visa operation ( |
  SetXAttrImpl | SetXAttr operation ( |
  SetXAttrBulkImpl | SetXAttr bulk operation ( |
  GetXAttrImpl | GetXAttr operation ( |
  GetXAttrBulkImpl | GetXAttr bulk operation ( |
  DelXAttrImpl | DelXAttr operation ( |
  DelXAttrBulkImpl | DelXAttr bulk operation ( |
  ListXAttrImpl | ListXAttr bulk operation ( |
  PgReadFlags | PgRead flags |
  FileStateHandler | Handle the stateful operations |
   RequestData | |
  QueryCode | XRootD query request codes |
  OpenFlags | Open flags, may be or'd when appropriate |
  Access | Access mode |
  MkDirFlags | MkDir flags |
  DirListFlags | DirList flags |
  PrepareFlags | Prepare flags |
  FileSystem | Send file/filesystem queries to an XRootD cluster |
  FileSystemOperation | |
  LocateImpl | Locate operation ( |
  DeepLocateImpl | DeepLocate operation ( |
  MvImpl | Mv operation ( |
  QueryImpl | Query operation ( |
  TruncateFsImpl | Truncate operation ( |
  RmImpl | Rm operation ( |
  MkDirImpl | MkDir operation ( |
  RmDirImpl | RmDir operation ( |
  ChModImpl | ChMod operation ( |
  PingImpl | Ping operation ( |
  StatFsImpl | Stat operation ( |
  StatVFSImpl | StatVS operation ( |
  ProtocolImpl | Protocol operation ( |
  DirListImpl | DirList operation ( |
  SendInfoImpl | SendInfo operation ( |
  PrepareImpl | Prepare operation ( |
  SetXAttrFsImpl | SetXAttr operation ( |
  SetXAttrFsBulkImpl | SetXAttr bulk operation ( |
  GetXAttrFsImpl | GetXAttr operation ( |
  GetXAttrFsBulkImpl | GetXAttr bulk operation ( |
  DelXAttrFsImpl | DelXAttr operation ( |
  DelXAttrFsBulkImpl | DelXAttr bulk operation ( |
  ListXAttrFsImpl | ListXAttr bulk operation ( |
  FileSystemUtils | |
   SpaceInfo | Container for space information |
  FileTimer | Task generating timeout events for FileStateHandlers in recovery mode |
  FinalOperation | |
  ForkHandler | |
  FSExecutor | Execute queries given as a commandline |
  FwdStorage | |
   Memory | Memory for the value |
  Fwd | |
  InQueue | A synchronize queue for incoming data |
  Job | Interface for a job to be run by the job manager |
  JobManager | A synchronized queue |
   JobHelper | |
  LocalFileHandler | |
  LocalFileTask | |
  LogOut | Interface for logger outputs |
  LogOutFile | Write log messages to a file |
  LogOutCerr | Write log messages to stderr |
  Log | Handle diagnostics |
  Message | The message representation used throughout the system |
  SyncResponseHandler | Synchronize the response |
  NullResponseHandler | |
  MessageSendParams | |
  MessageUtils | |
  MetalinkRedirector | |
  Monitor | An abstract class to describe the client-side monitoring plugin interface |
   CheckSumInfo | Describe a checksum event |
   CloseInfo | Describe a file close event |
   ConnectInfo | Describe a server login event |
   CopyBInfo | |
   CopyEInfo | Describe an end of copy event |
   DisconnectInfo | Describe a server logout event |
   ErrorInfo | Describe an encountered file-based error |
   OpenInfo | Describe a file open event to the monitor |
   TransferInfo | Describe the transfer |
  UnpackXAttrStatus | Helper class for unpacking single XAttrStatus from bulk response |
  UnpackXAttr | Helper class for unpacking single XAttr from bulk response |
  NullRef | |
  FunctionWrapper | |
  FunctionWrapper< void > | |
  TaskWrapper | |
  TaskWrapper< void, Return > | |
  ExOpenFuncWrapper | Lambda wrapper |
  PipelineException | Pipeline exception, wrapps an XRootDStatus |
  FutureWrapperBase | |
  FutureWrapper | |
  FutureWrapper< void > | A wrapper handler for a std::promise / std::future, overload for void type |
  RawWrapper | Wrapper class for raw response handler (ResponseHandler) |
  RespBase | |
  Resp | |
  Resp< void > | |
  Operation | |
  PipelineHandler | |
  Pipeline | |
  ConcreteOperation | |
  operation_expired | |
  Timeout | |
  None | None object for initializing empty Optional |
  Optional | |
   Storage | |
  OutQueue | A synchronized queue for the outgoing data |
   MsgHelper | |
  PolicyExecutor | |
  ParallelOperation | |
   AllPolicy | |
   AnyPolicy | |
   AtLeastPolicy | |
   barrier_t | A wait barrier helper class |
   Ctx | |
   PipelineEnd | The thread-pool job for schedule Ctx::Examine |
   SomePolicy | |
  FilePlugIn | An interface for file plug-ins |
  FileSystemPlugIn | An interface for file plug-ins |
  PlugInFactory | Plugin factory |
  PlugInManager | Manage client-side plug-ins and match them agains URLs |
   FactoryHelper | |
  SocketHandler | Interface |
  Poller | Interface for socket pollers |
  PollerBuiltIn | A poller implementation using the build-in XRootD poller |
  PollerFactory | Helper for creating poller objects |
  PostMaster | A hub for dispatching and receiving messages |
  MsgHandler | Message handler |
  ChannelEventHandler | Channel event handler |
  HandShakeData | Data structure that carries the handshake information |
  PathID | |
  TransportQuery | |
  TransportHandler | Perform the handshake and the authentication for each physical stream |
  PropertyList | A key-value pair map storing both keys and values as strings |
  RedirectJob | A job class for redirect handling in the thread-pool |
  VirtualRedirector | An interface for metadata redirectors |
  RedirectorRegistry | Singleton access to URL to virtual redirector mapping |
  RequestSync | A helper running a fixed number of requests at a given time |
  ResponseJob | Call the user callback |
  SIDManager | Handle XRootD stream IDs |
  SIDMgrPool | Pool of SID manager objects |
   RecycleSidMgr | A functional object for handling the deletion of SIDManager objects |
  Socket | A network socket |
  Status | Procedure execution status |
  Stream | Stream |
   HandleIncMsgJob | |
   QueueIncMsgJob | |
  SyncQueue | A synchronized queue |
  Task | Interface for a task to be run by the TaskManager |
  TaskManager | |
   TaskHelper | |
   TaskHelperCmp | |
  ThirdPartyCopyJob | |
  Tls | TLS layer for socket connection |
  TPFallBackCopyJob | |
  TransportManager | Manage transport handler objects |
  URL | URL representation |
  Utils | Random utilities |
  ScopedDescriptor | Smart descriptor - closes the descriptor on destruction |
  XCpCtx | |
  XCpSrc | |
  RedirectEntry | |
  XRootDMsgHandler | Handle/Process/Forward XRootD messages |
   ChunkStatus | |
  LocationInfo | Path location info |
   Location | Location |
  XRootDStatus | Request status |
  XAttrStatus | Extended attribute operation status |
  XAttr | Extended attributes with status |
  ProtocolInfo | Protocol response |
  StatInfo | Object stat info |
  StatInfoVFS | VFS stat info |
  DirectoryList | Directory list |
   ListEntry | Directory entry |
  OpenInfo | Information returned by file open operation |
  ChunkInfo | Describe a data chunk for vector read |
  PageInfo | |
  RetryInfo | |
  VectorReadInfo | Vector read info |
  HostInfo | |
  ResponseHandler | Handle an async response |
  XRootDQuery | XRootD related protocol queries |
  XRootDTransport | XRootD transport handler |
  ZipArchive | |
   NewFile | LFH of a newly appended file (in case it needs to be overwritten) |
  ZipError | An exception for carrying the XRootDStatus of InflCache |
  ZipCache | Utility class for inflating a compressed buffer |
   greater_read_resp_t | |
  ZipListHandler | |
  ZipOperation | |
  OpenArchiveImpl | OpenArchive operation ( |
  OpenFileImpl | OpenFile operation ( |
  ZipReadImpl | Read operation ( |
  ZipReadFromImpl | Read operation ( |
  ZipWriteImpl | Write operation ( |
  AppendFileImpl | AppendFile operation ( |
  CloseFileImpl | CloseFile operation ( |
  ZipStatImpl | ZipStat operation ( |
  ZipListImpl | ZipList operation ( |
  CloseArchiveImpl | CloseArchive operation ( |
  HttpFilePlugIn | |
  HttpFileSystemPlugIn | |
 xrdcl_proxy | |
  ProxyPrefixFile | |
  ProxyFactory | XrdCl proxy prefix plugin factory |
 XrdCms | |
  CmsRRHdr | |
  CmsResponse | |
  CmsAvailRequest | |
  CmsChmodRequest | |
  CmsDiscRequest | |
  CmsGoneRequest | |
  CmsHaveRequest | |
  CmsLocateRequest | |
  CmsLoginData | |
  CmsLoginRequest | |
  CmsLoginResponse | |
  CmsLoadRequest | |
  CmsMkdirRequest | |
  CmsMkpathRequest | |
  CmsMvRequest | |
  CmsPingRequest | |
  CmsPongRequest | |
  CmsPrepAddRequest | |
  CmsPrepDelRequest | |
  CmsRmRequest | |
  CmsRmdirRequest | |
  CmsSelectRequest | |
  CmsSpaceRequest | |
  CmsStateRequest | |
  CmsStatfsRequest | |
  CmsStatsRequest | |
  CmsStatusRequest | |
  CmsTruncRequest | |
  CmsTryRequest | |
  CmsUpdateRequest | |
  CmsUsageRequest | |
  SpaceData | |
 XrdEc | |
  OpenOnlyImpl | |
  Config | Global configuration for the EC module |
  ObjCfg | |
  Reader | |
  RedundancyProvider | |
   CodingTable | |
  StrmWriter | |
   global_status_t | |
  ThreadPool | |
   AnyJob | |
   seq_gen | |
   seq_gen< 0, Ns...> | |
   seq_gen< I, Ns...> | |
   sequence | |
  stripe_t | A buffer with stripe data and info on validity |
  IOError | Generic I/O exception, wraps up XrdCl::XRootDStatus ( |
  sync_queue | |
   wait_interrupted | |
  BufferPool | Pool of buffer for caching writes |
  WrtBuff | |
 XrdFrc | |
 XrdFrm | |
 XrdGlobal | |
 XrdNetSpace | |
 XrdOssStatEvent | |
 XrdPfc | |
  Configuration | Contains parameters configurable from the xrootd config file |
  TmpConfiguration | |
  SplitParser | |
  PathTokenizer | |
  Cache | Attaches/creates and detaches/deletes cache-io objects for disk based cache |
   WriteQ | |
  Decision | Base class for selecting which files should be cached |
  Block | |
  BlockResponseHandler | |
  DirectResponseHandler | |
  File | |
   IODetails | |
  Info | Status of cached file. Can be read from and written into a binary file |
   AStat | Access statistics |
   Status | |
   Store | |
  IO | Base cache-io class that implements XrdOucCacheIO abstract methods |
  IOEntireFile | Downloads original file into a single file on local disk. Handles read requests as they come along |
  IOFileBlock | Downloads original file into multiple files, chunked into blocks. Only blocks that are asked for are downloaded. Handles read requests as they come along |
  Print | |
  Stats | Statistics of cache utilisation by a File object |
 XrdPosixGlobals | |
 XrdProto | |
  read_list | |
  write_list | |
 XrdSecsssMap | |
 XrdSfs | |
 XrdSsi | |
  ShMap_Parms | |
  ShMap | |
 XrdSys | |
  IOEvents | |
   CallBack | |
   Channel | |
    dlQ | |
   Poller | |
    PipeData | |
  KernelBuffer | |
  RAtomic | |
  RAtomic< T * > | |
  RAtomic< bool > | |
 XrdThrottle | |
  File | |
  FileSystem | |
 XrdXrootd | |
  Bridge | |
   Context | |
   Result | |
  gdCallBack | |
  IOParms | |
 XrdZip | |
  CDFH | |
  DataDescriptor | |
  EOCD | |
  Extra | |
  LFH | A data structure representing ZIP Local File Header |
  bad_data | |
  ovrflw | |
  dos_timestmp | |
  ZIP64_EOCD | |
  ZIP64_EOCDL | A data structure representing the ZIP64 end of central directory locator |
 aiocb | |
 ALIGN_CHECK | |
 ClientAuthRequest | |
 ClientBindRequest | |
 ClientChkPointRequest | |
 ClientChmodRequest | |
 ClientCloseRequest | |
 ClientDirlistRequest | |
 ClientEndsessRequest | |
 ClientFattrRequest | |
 ClientGPfileRequest | |
 ClientInitHandShake | |
 ClientLocateRequest | |
 ClientLoginRequest | |
 ClientMkdirRequest | |
 ClientMvRequest | |
 ClientOpenRequest | |
 ClientPgReadReqArgs | |
 ClientPgReadRequest | |
 ClientPgWriteRequest | |
 ClientPingRequest | |
 ClientPrepareRequest | |
 ClientProtocolRequest | |
 ClientQueryRequest | |
 ClientReadRequest | |
 ClientReadVRequest | |
 ClientRequest | |
 ClientRequestHdr | |
 ClientRmdirRequest | |
 ClientRmRequest | |
 ClientSetRequest | |
 ClientSigverRequest | |
 ClientStatRequest | |
 ClientSyncRequest | |
 ClientTruncateRequest | |
 ClientWriteRequest | |
 ClientWriteVRequest | |
 DirListInfo | |
 EnvInitializer | |
 gsiHSVars | |
 gsiOptions | |
 GSIStack | |
 HttpPlugInFactory | |
 iov | |
 OssDPath | |
 OssSpaceConfig | |
 ProxyIn_t | |
 ProxyOut_t | |
 pwdHSVars | |
 pwdOptions | |
 pwdStatus_t | |
 read_args | |
 readahead_list | |
 ReadWriteOp | |
 SecurityRequest | |
 ServerInitHandShake | |
 ServerResponse | |
 ServerResponseBifs_Protocol | |
 ServerResponseBody_Attn | |
 ServerResponseBody_Attn_asyncms | |
 ServerResponseBody_Attn_asynresp | |
 ServerResponseBody_Authmore | |
 ServerResponseBody_Bind | |
 ServerResponseBody_Buffer | |
 ServerResponseBody_ChkPoint | |
 ServerResponseBody_Error | |
 ServerResponseBody_Login | |
 ServerResponseBody_Open | |
 ServerResponseBody_pgRead | |
 ServerResponseBody_pgWrCSE | |
 ServerResponseBody_pgWrite | |
 ServerResponseBody_Protocol | |
 ServerResponseBody_Redirect | |
 ServerResponseBody_Status | |
 ServerResponseBody_Wait | |
 ServerResponseBody_Waitresp | |
 ServerResponseHeader | |
 ServerResponseReqs_Protocol | |
 ServerResponseStatus | |
 ServerResponseSVec_Protocol | |
 ServerResponseV2 | |
 TagPath | |
 Voms_x509_in_t | |
 x509ChainVerifyOpt_t | |
 XProtocol | |
  ServerResponseBody_Attn_asyncdi | |
  ServerResponseBody_Attn_asyncrd | |
  ServerResponseBody_Attn_asyncwt | |
 XrdAccAccess | |
 XrdAccAccess_ID | |
 XrdAccAccess_Tables | |
 XrdAccAudit | |
 XrdAccAuthDB | |
 XrdAccAuthFile | |
 XrdAccAuthorize | |
 XrdAccCapability | |
 XrdAccCapName | |
 XrdAccConfig | |
 XrdAccEntity | |
  EntityAttr | |
 XrdAccEntityInfo | |
 XrdAccEntityInit | |
 XrdAccGlist | |
 XrdAccGroupList | |
 XrdAccGroups | |
 XrdAccPrivCaps | |
 XrdBuffer | |
 XrdBuffManager | |
 XrdBuffXL | |
  BuckVec | |
 XrdBwm | |
 XrdBwmDirectory | |
 XrdBwmFile | |
 XrdBwmHandle | |
  theEICB | |
 XrdBwmLogger | |
  Info | |
 XrdBwmPolicy | |
  SchedParms | |
 XrdBwmPolicy1 | |
  refReq | |
  refSch | |
 XrdCephOss | |
 XrdCephOssDir | |
 XrdCephOssFile | |
 XrdCephXAttr | |
 XrdCks | |
 XrdCksCalc | |
 XrdCksCalcadler32 | |
 XrdCksCalccrc32 | |
 XrdCksCalccrc32C | |
 XrdCksCalcmd5 | |
  MD5Context | |
 XrdCksConfig | |
 XrdCksData | |
 XrdCksLoader | |
  csInfo | |
 XrdCksManager | |
  csInfo | |
 XrdCksManOss | |
 XrdCksPCB | |
 XrdCksWrapper | |
 XrdCksXAttr | |
 XrdCmsAdmin | |
 XrdCmsBaseFR | |
 XrdCmsBaseFS | |
  dMoP | |
  RequestQ | |
 XrdCmsBlackList | |
 XrdCmsCache | |
 XrdCmsClient | |
 XrdCmsClientConfig | |
 XrdCmsClientMan | |
 XrdCmsClientMsg | |
 XrdCmsCluster | |
 XrdCmsClustID | |
 XrdCmsConfig | |
 XrdCmsFinderRMT | |
 XrdCmsFinderTRG | |
 XrdCmsJob | |
 XrdCmsKey | |
 XrdCmsKeyItem | |
 XrdCmsKeyLoc | |
 XrdCmsLogin | |
 XrdCmsManager | |
 XrdCmsManList | |
 XrdCmsManTree | |
  TreeInfo | |
 XrdCmsMeter | |
 XrdCmsNash | |
 XrdCmsNode | |
 XrdCmsParser | |
 XrdCmsPerfMon | |
  PerfInfo | Structure used for reporting performance metrics |
 XrdCmsPInfo | |
 XrdCmsPList | |
 XrdCmsPList_Anchor | |
 XrdCmsPrepare | |
 XrdCmsPrepArgs | |
 XrdCmsProtocol | |
 XrdCmsRedirLocal | |
 XrdCmsResp | |
 XrdCmsRespCB | |
 XrdCmsRespQ | |
 XrdCmsRLData | |
 XrdCmsRole | |
 XrdCmsRouter | |
  theRoute | |
 XrdCmsRouting | |
  theRouting | |
 XrdCmsRRData | |
 XrdCmsRRQ | |
  Info | |
 XrdCmsRRQInfo | |
 XrdCmsRRQSlot | |
 XrdCmsRTable | |
 XrdCmsSecurity | |
 XrdCmsSelect | |
 XrdCmsSelected | |
 XrdCmsSelector | |
 XrdCmsState | |
 XrdCmsSupervisor | |
 XrdCmsTalk | |
 XrdCmsUtils | |
 XrdConfig | |
 XrdCpConfig | |
  defVar | |
 XrdCpFile | |
 XrdCryptoBasic | |
 XrdCryptoCipher | |
 XrdCryptoFactory | |
 XrdCryptogsiX509Chain | |
 XrdCryptoLite | |
 XrdCryptoMsgDigest | |
 XrdCryptoRSA | |
 XrdCryptosslCipher | |
 XrdCryptosslFactory | |
 XrdCryptosslMsgDigest | |
 XrdCryptosslRSA | |
 XrdCryptosslX509 | |
 XrdCryptosslX509Crl | |
 XrdCryptosslX509Req | |
 XrdCryptoX509 | |
 XrdCryptoX509Chain | |
 XrdCryptoX509ChainNode | |
 XrdCryptoX509Crl | |
 XrdCryptoX509Req | |
 XrdDigAuth | |
 XrdDigAuthEnt | |
 XrdDigConfig | |
 XrdDigDirectory | |
 XrdDigFile | |
 XrdDigFS | |
 XrdFfsDentnames | |
 XrdFfsQueueTasks | |
 XrdFrcCID | |
  cidEnt | |
  cidMon | |
 XrdFrcProxy | |
  o2qMap | |
  Queues | |
 XrdFrcReqAgent | |
 XrdFrcReqFile | |
  FileHdr | |
  recEnt | |
  rqMonitor | |
 XrdFrcRequest | |
 XrdFrcUtils | |
 XrdFrcXAttrCpy | |
 XrdFrcXAttrMem | |
 XrdFrcXAttrPfn | |
 XrdFrcXAttrPin | |
 XrdFrcXLock | |
 XrdFrmAdmin | |
 XrdFrmCns | |
 XrdFrmConfig | |
  Cmd | |
  Policy | |
  VPInfo | |
 XrdFrmFiles | |
 XrdFrmFileset | |
 XrdFrmMigrate | |
 XrdFrmMonitor | |
 XrdFrmPurge | |
 XrdFrmReqBoss | |
 XrdFrmTransfer | |
 XrdFrmTSort | |
 XrdFrmXfrAgent | |
 XrdFrmXfrDaemon | |
 XrdFrmXfrJob | |
 XrdFrmXfrQueue | |
  theQueue | |
 XrdHttpExtHandler | |
 XrdHttpExtReq | |
 XrdHttpProtocol | |
  extHInfo | |
  StaticPreloadInfo | |
  XrdHttpExtHandlerInfo | |
 XrdHttpReq | |
 XrdHttpSecXtractor | |
 XrdInet | |
 XrdJob | |
 XrdLink | |
 XrdLinkCtl | |
 XrdLinkInfo | |
 XrdLinkMatch | |
 XrdLinkXeq | |
 XrdMpxXml | |
  VarInfo | |
 XrdNet | |
 XrdNetAddr | |
 XrdNetAddrInfo | |
  LocInfo | |
 XrdNetBuffer | |
 XrdNetBufferQ | |
 XrdNetCache | |
  anItem | |
 XrdNetCmsNotify | |
 XrdNetConnect | |
 XrdNetIdentity | |
 XrdNetIF | |
  ifAddrs | |
  ifData | |
  pInfo | |
 XrdNetMsg | |
 XrdNetPeer | |
 XrdNetPMark | |
  Handle | |
 XrdNetPMarkCfg | |
 XrdNetPMarkFF | |
 XrdNetRegistry | |
 XrdNetSecurity | |
 XrdNetSockAddr | |
 XrdNetSocket | |
 XrdNetUtils | |
 XrdObject | |
 XrdObjectQ | |
 XrdOfs | |
  fwdOpt | |
 XrdOfsChkPnt | |
 XrdOfsConfigCP | |
  Stats | |
 XrdOfsConfigPI | |
  ctlLP | |
  xxxLP | |
 XrdOfsCPFile | |
  rInfo | |
 XrdOfsDirectory | |
 XrdOfsDirFull | |
 XrdOfsEvr | |
  theClient | |
  theEvent | |
 XrdOfsEvs | |
 XrdOfsEvsFormat | |
 XrdOfsEvsInfo | |
 XrdOfsFile | |
 XrdOfsFileFull | |
 XrdOfsFSctl_PI | |
  Plugins | The Plugins struct is used to pass plugin pointers to configure |
 XrdOfsHanCB | |
 XrdOfsHandle | |
 XrdOfsHanKey | |
 XrdOfsHanTab | |
 XrdOfsPoscq | |
  FileSlot | |
  recEnt | |
  Request | |
 XrdOfsPrepare | |
 XrdOfsStats | |
  StatsData | |
 XrdOfsTPC | |
  Facts | |
 XrdOfsTPCAuth | |
 XrdOfsTPCConfig | |
 XrdOfsTPCInfo | |
 XrdOfsTPCJob | |
 XrdOfsTPCProg | |
 XrdOss | |
 XrdOssAt | |
 XrdOssCache | |
  allocInfo | |
 XrdOssCache_FS | |
 XrdOssCache_FSAP | |
 XrdOssCache_FSData | |
 XrdOssCache_Group | |
 XrdOssCache_Space | |
 XrdOssCopy | |
 XrdOssCsi | |
 XrdOssCsiConfig | |
 XrdOssCsiCrcUtils | |
 XrdOssCsiDir | |
 XrdOssCsiFile | |
  puMapItem_t | |
 XrdOssCsiFileAio | |
 XrdOssCsiFileAioJob | |
 XrdOssCsiFileAioStore | |
 XrdOssCsiPages | |
 XrdOssCsiRange_s | |
 XrdOssCsiRangeGuard | |
 XrdOssCsiRanges | |
 XrdOssCsiTagstore | |
 XrdOssCsiTagstoreFile | |
 XrdOssDF | |
 XrdOssDFHandler | |
 XrdOssDir | |
 XrdOssFile | |
 XrdOssHandler | |
 XrdOssMio | |
 XrdOssMioFile | |
 XrdOssPath | |
  fnInfo | |
 XrdOssSpace | |
  uEnt | |
 XrdOssStage_Req | |
 XrdOssSys | |
 XrdOssVSInfo | |
 XrdOssVSPart | |
 XrdOssWrapDF | |
 XrdOssWrapper | |
 XrdOuca2x | |
 XrdOucArgs | |
 XrdOucBackTrace | |
 XrdOucBuffer | |
 XrdOucBuffPool | |
  BuffSlot | |
 XrdOucCache | |
 XrdOucCacheIO | |
  aprParms | |
 XrdOucCacheIOCB | |
 XrdOucCacheIOCD | |
 XrdOucCacheStats | |
  CacheStats | |
 XrdOucCallBack | |
 XrdOucChkPnt | |
 XrdOucCRC | |
 XrdOucDLlist | |
 XrdOucEI | |
 XrdOucEICB | |
 XrdOucEnv | |
 XrdOucERoute | |
 XrdOucErrInfo | |
 XrdOucExport | |
 XrdOucFileInfo | |
 XrdOucGatherConf | |
 XrdOucGMap | |
 XrdOucHash | |
 XrdOucHash_Item | |
 XrdOucIOVec | |
 XrdOucIOVec2 | |
 XrdOucLock | |
 XrdOucLogging | |
  configLogInfo | |
 XrdOucMapP2X | |
 XrdOucMsubs | |
 XrdOucMsubsInfo | |
 XrdOucN2NLoader | |
 XrdOucName2Name | |
 XrdOucName2NameVec | XrdOucName2NameVec *Name2NameVec; |
 XrdOucNList | |
 XrdOucNList_Anchor | |
 XrdOucNSWalk | |
  CallBack | |
  NSEnt | |
 XrdOucPgrwUtils | |
  dataInfo | |
  Layout | Compute the layout for an iovec that receives network bytes applying |
 XrdOucPinKing | |
  pinInfo | |
 XrdOucPinLoader | |
 XrdOucPinObject | |
 XrdOucPList | |
 XrdOucPListAnchor | |
 XrdOucProg | |
 XrdOucPsx | |
 XrdOucPup | |
 XrdOucPupArgs | |
 XrdOucPupNames | |
 XrdOucQSItem | |
 XrdOucQueue | |
 XrdOucRash | |
 XrdOucRash_Item | |
 XrdOucRash_Tent | |
 XrdOucReqID | |
 XrdOucSFVec | |
 XrdOucSHA3 | |
  sha3_ctx_t | SHA3 state context used by all methods (OpenSSL - like interface) |
 XrdOucSid | |
  theSid | The type to pass to Obtain(). Simply cast the char[2] to (theSid *) |
 XrdOucSiteName | |
 XrdOucStack | |
 XrdOucStats | |
 XrdOucStream | |
 XrdOucString | |
 XrdOucSxeq | |
 XrdOucTable | |
  OucTable | |
 XrdOucTList | |
 XrdOucTListFIFO | |
 XrdOucTListHelper | |
 XrdOucTokenizer | |
 XrdOucTPC | |
  tpcInfo | |
 XrdOucTrace | |
 XrdOucUri | |
 XrdOucUtils | |
 XrdOucVerName | |
 XrdOucXAttr | |
 XrdPoll | |
  PipeData | |
 XrdPollE | |
 XrdPollInfo | |
 XrdPollPoll | |
 XrdPosixAdmin | |
 XrdPosixCache | |
 XrdPosixCallBack | An abstract class to define a callback for Open() call |
 XrdPosixCallBackIO | |
 XrdPosixConfig | |
 XrdPosixDir | |
 XrdPosixExtra | Extended POSIX interface to XRootD |
 XrdPosixFile | |
 XrdPosixFileRH | |
 XrdPosixInfo | |
 XrdPosixLinkage | |
 XrdPosixMap | |
 XrdPosixObject | |
 XrdPosixObjGuard | |
 XrdPosixPrepIO | |
 XrdPosixStats | |
  PosixStats | |
 XrdPosixXrootd | POSIX interface to XRootD with some extensions, as noted |
 XrdPosixXrootPath | |
  xpath | |
 XrdProtLoad | |
 XrdProtocol | |
 XrdProtocol_Config | |
 XrdProxyOpt_t | |
 XrdPssAioCB | |
 XrdPssCks | |
  csInfo | |
 XrdPssDir | |
 XrdPssFile | |
  tprInfo | |
 XrdPssSys | |
 XrdPssUrlInfo | |
 XrdPssUtils | |
 XrdRmc | |
  Parms | Parameters for a newly created memory cache |
 XrdRmcData | |
  MrSw | |
 XrdRmcReal | |
  prTask | |
 XrdRmcSlot | |
  ioQ | |
  SlotList | |
  SlotState | |
 XrdScheduler | |
 XrdSciTokensHelper | |
  ValidIssuer | |
 XrdSecAttr | |
 XrdSecBuffer | Generic structure to pass security information back and forth |
 XrdSecEntity | |
 XrdSecEntityAttr | |
 XrdSecEntityAttrCB | |
 XrdSecEntityPin | |
 XrdSecEntityXtra | |
 XrdSecGMapEntry_t | |
 XrdSecPManager | |
 XrdSecProtect | |
 XrdSecProtector | |
 XrdSecProtectParms | |
 XrdSecProtocol | |
 XrdSecProtocolgsi | |
 XrdSecProtocolhost | |
 XrdSecProtocolpwd | |
 XrdSecProtocolsss | |
  Crypto | |
 XrdSecServer | |
 XrdSecService | |
 XrdSecsssCon | |
 XrdSecsssEnt | |
 XrdSecsssID | |
 XrdSecsssKT | |
  ktEnt | |
   ktData | |
 XrdSecsssRR_Data | |
 XrdSecsssRR_DataHdr | |
 XrdSecsssRR_DataResp | |
 XrdSecsssRR_Hdr | |
 XrdSecsssRR_Hdr2 | |
 XrdSecTLayer | |
  TLayerRR | |
 XrdSendQ | |
  mBuff | |
 XrdSfsAio | |
 XrdSfsDio | |
 XrdSfsDirectory | |
 XrdSfsFABuff | |
 XrdSfsFACtl | |
 XrdSfsFAInfo | |
 XrdSfsFile | |
 XrdSfsFSctl | < SFS_FSCTL_PLUGIN/PLUGIO parms |
 XrdSfsGPFile | |
 XrdSfsNative | |
 XrdSfsNativeDirectory | |
 XrdSfsNativeFile | |
 XrdSfsPrep | < Prepare parameters |
 XrdSfsXio | |
 XrdSfsXioImpl | |
 XrdSsiAlert | |
 XrdSsiBVec | |
 XrdSsiCluster | |
 XrdSsiCms | |
 XrdSsiDir | |
 XrdSsiEntity | |
 XrdSsiErrInfo | |
 XrdSsiEvent | |
  EventData | |
 XrdSsiFile | |
 XrdSsiFileReq | |
 XrdSsiFileResource | |
 XrdSsiFileSess | |
 XrdSsiLogger | |
 XrdSsiMutex | |
 XrdSsiMutexMon | |
 XrdSsiProvider | |
 XrdSsiRequest | |
 XrdSsiResource | |
 XrdSsiRespInfo | |
 XrdSsiRespInfoMsg | |
 XrdSsiResponder | |
 XrdSsiRRAgent | |
 XrdSsiRRInfo | |
 XrdSsiRRInfoAttn | |
 XrdSsiRRTable | |
 XrdSsiScale | |
 XrdSsiService | |
 XrdSsiServReal | |
 XrdSsiSessReal | |
 XrdSsiSfs | |
 XrdSsiSfsConfig | |
 XrdSsiShMam | |
  MemItem | |
  XLockHelper | |
 XrdSsiShMat | |
  CRZParms | |
  NewParms | |
 XrdSsiStats | |
 XrdSsiStream | |
  Buffer | |
 XrdSsiTaskReal | |
  dlQ | |
 XrdSsiUtils | |
 XrdStats | |
  CallBack | |
 XrdSutBucket | |
 XrdSutBuckList | |
 XrdSutBuckListNode | |
 XrdSutBuffer | |
 XrdSutCache | |
 XrdSutCacheArg_t | |
 XrdSutCacheEntry | |
 XrdSutCacheEntryBuf | |
 XrdSutCERef | |
 XrdSutFileLocker | |
 XrdSutPFBuf | |
 XrdSutPFCache | |
 XrdSutPFCacheRef | |
 XrdSutPFEntInd | |
 XrdSutPFEntry | |
 XrdSutPFHeader | |
 XrdSutPFile | |
 XrdSutRndm | |
 XrdSysCondVar | |
 XrdSysCondVar2 | |
 XrdSysCondVarHelper | |
 XrdSysDir | |
 XrdSysError | |
 XrdSysError_Table | |
 XrdSysFAttr | |
 XrdSysFusedMutex | |
 XrdSysLogger | |
  mmMsg | |
  Task | |
 XrdSysLogging | |
  MsgBuff | |
  Parms | Parameters to be passed to configure |
 XrdSysMutex | |
 XrdSysMutexHelper | |
 XrdSysPlugin | |
  PLlist | |
 XrdSysPriv | |
 XrdSysPrivGuard | |
 XrdSysPwd | |
 XrdSysRecMutex | |
 XrdSysRWLock | |
 XrdSysRWLockHelper | |
 XrdSysSemaphore | |
 XrdSysSemWait | |
 XrdSysThread | |
 XrdSysTimer | |
 XrdSysTrace | |
 XrdSysUtils | |
 XrdSysXAttr | |
  AList | |
 XrdSysXSLock | |
 XrdTcpMonPin | |
  LinkInfo | |
 XrdThrottleManager | |
 XrdThrottleTimer | |
 XrdTls | |
 XrdTlsContext | |
  CTX_Params | |
 XrdTlsNotary | |
 XrdTlsPeerCerts | |
 XrdTlsSocket | Socket wrapper for TLS I/O |
 XrdTlsTempCA | |
  TempCAGuard | |
 XrdVersionMapD2P | |
 XrdVersionPlugin | |
 XrdVomsFun | |
 XrdXmlMetaLink | |
 XrdXmlRdrTiny | |
 XrdXmlRdrXml2 | |
 XrdXmlReader | |
 XrdXrootdAdmin | |
  JobTable | |
  usr | |
 XrdXrootdAioBuff | |
 XrdXrootdAioFob | |
  AioTasks | |
 XrdXrootdAioPgrw | |
 XrdXrootdAioTask | |
 XrdXrootdCallBack | |
 XrdXrootdFHandle | |
 XrdXrootdFile | |
 XrdXrootdFileHP | |
 XrdXrootdFileLock | |
 XrdXrootdFileLock1 | |
 XrdXrootdFileStats | |
 XrdXrootdFileTable | |
 XrdXrootdGPFile | |
 XrdXrootdGPFileInfo | |
 XrdXrootdGSReal | |
  GSParms | |
  HdrInfo | |
 XrdXrootdGStream | |
 XrdXrootdJob | |
 XrdXrootdMonBuff | |
 XrdXrootdMonBurr | |
 XrdXrootdMonDouble | |
 XrdXrootdMonFile | |
 XrdXrootdMonFileCLS | |
 XrdXrootdMonFileDSC | |
 XrdXrootdMonFileHdr | |
 XrdXrootdMonFileLFN | |
 XrdXrootdMonFileOPN | |
 XrdXrootdMonFileTOD | |
 XrdXrootdMonFileXFR | |
 XrdXrootdMonFMap | |
  cvPtr | |
 XrdXrootdMonGS | |
 XrdXrootdMonHeader | |
 XrdXrootdMonitor | |
  Hello | |
  MonRdrBuff | |
  User | |
 XrdXrootdMonMap | |
 XrdXrootdMonRedir | |
 XrdXrootdMonStatOPS | |
 XrdXrootdMonStatPRW | |
 XrdXrootdMonStatSSQ | |
 XrdXrootdMonStatXFR | |
 XrdXrootdMonTrace | |
 XrdXrootdNormAio | |
 XrdXrootdPgrwAio | |
 XrdXrootdPgwBadCS | |
 XrdXrootdPgwCtl | |
 XrdXrootdPgwFob | |
 XrdXrootdPio | |
 XrdXrootdPrepare | |
 XrdXrootdPrepArgs | |
 XrdXrootdProtocol | |
  GetDataCtl | |
  RC_Table | |
  RD_Table | |
 XrdXrootdReqID | |
 XrdXrootdResponse | |
 XrdXrootdStats | |
 XrdXrootdTransit | |
  SchedReq | |
 XrdXrootdTransPend | |
 XrdXrootdTransSend | |
 XrdXrootdWVInfo | |
 XrdXrootdXPath | |