| 
 | ||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||
| Uses of Configurable in org.apache.flume | 
|---|
| Subinterfaces of Configurable in org.apache.flume | |
|---|---|
|  interface | ChannelSelectorAllows the selection of a subset of channels from the given set based on its implementation policy. | 
|  interface | SinkProcessorInterface for a device that allows abstraction of the behavior of multiple sinks, always assigned to a SinkRunner | 
| Uses of Configurable in org.apache.flume.agent.embedded | 
|---|
| Classes in org.apache.flume.agent.embedded that implement Configurable | |
|---|---|
|  class | EmbeddedSourceSimple source used to allow direct access to the channel for the Embedded Agent. | 
| Uses of Configurable in org.apache.flume.channel | 
|---|
| Classes in org.apache.flume.channel that implement Configurable | |
|---|---|
|  class | AbstractChannel | 
|  class | AbstractChannelSelector | 
|  class | BasicChannelSemanticsAn implementation of basic Channelsemantics, including the
 implied thread-local semantics of theTransactionclass,
 which is required to extendBasicTransactionSemantics. | 
|  class | ChannelProcessorA channel processor exposes operations to put Events intoChannels. | 
|  class | MemoryChannelMemoryChannel is the recommended channel to use when speeds which writing to disk is impractical is required or durability of data is not required. | 
|  class | MultiplexingChannelSelector | 
|  class | PseudoTxnMemoryChannelA capacity-capped Channelimplementation that supports in-memory
 buffering and delivery of events. | 
|  class | ReplicatingChannelSelectorReplicating channel selector. | 
|  class | SpillableMemoryChannelSpillableMemoryChannel will use main memory for buffering events until it has reached capacity. | 
| Uses of Configurable in org.apache.flume.channel.file | 
|---|
| Classes in org.apache.flume.channel.file that implement Configurable | |
|---|---|
|  class | FileChannelA durable Channelimplementation that uses the local file system for
 its storage. | 
| Uses of Configurable in org.apache.flume.channel.jdbc | 
|---|
| Classes in org.apache.flume.channel.jdbc that implement Configurable | |
|---|---|
|  class | JdbcChannelA JDBC based channel implementation. | 
| Uses of Configurable in org.apache.flume.instrumentation | 
|---|
| Subinterfaces of Configurable in org.apache.flume.instrumentation | |
|---|---|
|  interface | MonitorServiceInterface that any monitoring service should implement. | 
| Classes in org.apache.flume.instrumentation that implement Configurable | |
|---|---|
|  class | GangliaServerA Ganglia server that polls JMX based at a configured frequency (defaults to once every 60 seconds). | 
| Uses of Configurable in org.apache.flume.instrumentation.http | 
|---|
| Classes in org.apache.flume.instrumentation.http that implement Configurable | |
|---|---|
|  class | HTTPMetricsServerA Monitor service implementation that runs a web server on a configurable port and returns the metrics for components in JSON format. | 
| Uses of Configurable in org.apache.flume.interceptor | 
|---|
| Subinterfaces of Configurable in org.apache.flume.interceptor | |
|---|---|
| static interface | Interceptor.BuilderBuilder implementations MUST have a no-arg constructor | 
|  interface | RegexExtractorInterceptorSerializerSerializer for serializing groups matched by the RegexExtractorInterceptor | 
| Classes in org.apache.flume.interceptor that implement Configurable | |
|---|---|
| static class | HostInterceptor.BuilderBuilder which builds new instances of the HostInterceptor. | 
| static class | RegexExtractorInterceptor.Builder | 
|  class | RegexExtractorInterceptorMillisSerializerSerializer that converts the passed in value into milliseconds using the specified formatting pattern | 
|  class | RegexExtractorInterceptorPassThroughSerializerSerializer that simply returns the passed in value | 
| static class | RegexFilteringInterceptor.BuilderBuilder which builds new instance of the StaticInterceptor. | 
| static class | StaticInterceptor.BuilderBuilder which builds new instance of the StaticInterceptor. | 
| static class | TimestampInterceptor.BuilderBuilder which builds new instances of the TimestampInterceptor. | 
| Uses of Configurable in org.apache.flume.serialization | 
|---|
| Classes in org.apache.flume.serialization that implement Configurable | |
|---|---|
|  class | AbstractAvroEventSerializer<T>This is a helper class provided to make it straightforward to serialize Flume events into Avro data. | 
|  class | FlumeEventAvroEventSerializer | 
| Uses of Configurable in org.apache.flume.sink | 
|---|
| Subinterfaces of Configurable in org.apache.flume.sink | |
|---|---|
| static interface | LoadBalancingSinkProcessor.SinkSelectorAn interface that allows the LoadBalancingSinkProcessor to use a load-balancing strategy such as round-robin, random distribution etc. | 
| Classes in org.apache.flume.sink that implement Configurable | |
|---|---|
|  class | AbstractRpcSinkThis sink provides the basic RPC functionality for Flume. | 
|  class | AbstractSinkProcessorA convenience base class for sink processors. | 
|  class | AbstractSinkSelector | 
|  class | AvroSinkA Sinkimplementation that can send events to an RPC server (such as
 Flume'sAvroSource). | 
|  class | DefaultSinkProcessorDefault sink processor that only accepts a single sink, passing on process results without any additional handling. | 
|  class | FailoverSinkProcessorFailoverSinkProcessor maintains a prioritized list of sinks, guarranteeing that so long as one is available events will be processed. | 
|  class | LoadBalancingSinkProcessorProvides the ability to load-balance flow over multiple sinks. | 
|  class | NullSinkA Sinkimplementation that simply discards all events it receives. | 
|  class | RollingFileSink | 
|  class | SinkGroupConfiguration concept for handling multiple sinks working together. | 
|  class | ThriftSinkA Sinkimplementation that can send events to an RPC server (such as
 Flume'sThriftSource). | 
| Uses of Configurable in org.apache.flume.sink.elasticsearch | 
|---|
| Subinterfaces of Configurable in org.apache.flume.sink.elasticsearch | |
|---|---|
|  interface | ElasticSearchEventSerializerInterface for an event serializer which serializes the headers and body of an event to write them to ElasticSearch. | 
|  interface | ElasticSearchIndexRequestBuilderFactoryInterface for creating ElasticSearch IndexRequestBuilderinstances
 from serialized flume events. | 
|  interface | IndexNameBuilder | 
| Classes in org.apache.flume.sink.elasticsearch that implement Configurable | |
|---|---|
|  class | AbstractElasticSearchIndexRequestBuilderFactoryAbstract base class for custom implementations of ElasticSearchIndexRequestBuilderFactory. | 
|  class | ElasticSearchDynamicSerializerBasic serializer that serializes the event body and header fields into individual fields | 
|  class | ElasticSearchLogStashEventSerializerSerialize flume events into the same format LogStash uses | 
|  class | ElasticSearchSinkA sink which reads events from a channel and writes them to ElasticSearch based on the work done by https://github.com/Aconex/elasticflume.git. | 
|  class | EventSerializerIndexRequestBuilderFactoryDefault implementation of ElasticSearchIndexRequestBuilderFactory. | 
|  class | SimpleIndexNameBuilder | 
|  class | TimeBasedIndexNameBuilderDefault index name builder. | 
| Uses of Configurable in org.apache.flume.sink.elasticsearch.client | 
|---|
| Subinterfaces of Configurable in org.apache.flume.sink.elasticsearch.client | |
|---|---|
|  interface | ElasticSearchClientInterface for an ElasticSearch client which is responsible for sending bulks of events to ElasticSearch. | 
| Classes in org.apache.flume.sink.elasticsearch.client that implement Configurable | |
|---|---|
|  class | ElasticSearchRestClientRest ElasticSearch client which is responsible for sending bulks of events to ElasticSearch using ElasticSearch HTTP API. | 
|  class | ElasticSearchTransportClient | 
| Uses of Configurable in org.apache.flume.sink.hbase | 
|---|
| Subinterfaces of Configurable in org.apache.flume.sink.hbase | |
|---|---|
|  interface | AsyncHbaseEventSerializerInterface for an event serializer which serializes the headers and body of an event to write them to hbase. | 
|  interface | HbaseEventSerializerInterface for an event serializer which serializes the headers and body of an event to write them to hbase. | 
| Classes in org.apache.flume.sink.hbase that implement Configurable | |
|---|---|
|  class | AsyncHBaseSinkA simple sink which reads events from a channel and writes them to HBase. | 
|  class | HBaseSinkA simple sink which reads events from a channel and writes them to HBase. | 
|  class | RegexHbaseEventSerializerAn HbaseEventSerializerwhich parses columns based on a supplied 
 regular expression and column name list. | 
|  class | SimpleAsyncHbaseEventSerializerA simple serializer to be used with the AsyncHBaseSink that returns puts from an event, by writing the event body into it. | 
|  class | SimpleHbaseEventSerializerA simple serializer that returns puts from an event, by writing the event body into it. | 
| Uses of Configurable in org.apache.flume.sink.hdfs | 
|---|
| Subinterfaces of Configurable in org.apache.flume.sink.hdfs | |
|---|---|
|  interface | HDFSWriter | 
| Classes in org.apache.flume.sink.hdfs that implement Configurable | |
|---|---|
|  class | AbstractHDFSWriter | 
|  class | AvroEventSerializerThis class serializes Flume events into Avro data files. | 
|  class | HDFSCompressedDataStream | 
|  class | HDFSDataStream | 
|  class | HDFSEventSink | 
|  class | HDFSSequenceFile | 
| Uses of Configurable in org.apache.flume.sink.irc | 
|---|
| Classes in org.apache.flume.sink.irc that implement Configurable | |
|---|---|
|  class | IRCSink | 
| Uses of Configurable in org.apache.flume.sink.solr.morphline | 
|---|
| Subinterfaces of Configurable in org.apache.flume.sink.solr.morphline | |
|---|---|
|  interface | MorphlineHandlerInterface to load Flume events into Solr | 
| Classes in org.apache.flume.sink.solr.morphline that implement Configurable | |
|---|---|
|  class | BlobHandlerBlobHandler for HTTPSource that returns event that contains the request parameters as well as the Binary Large Object (BLOB) uploaded with this request. | 
|  class | MorphlineHandlerImplA MorphlineHandlerthat processes it's events using a morphlineCommandchain. | 
| static class | MorphlineInterceptor.BuilderBuilder implementations MUST have a public no-arg constructor | 
|  class | MorphlineSinkFlume sink that extracts search documents from Flume events and processes them using a morphline Commandchain. | 
|  class | MorphlineSolrSinkFlume sink that extracts search documents from Flume events, processes them using a morphline Commandchain, and loads them into Apache Solr. | 
| static class | UUIDInterceptor.BuilderBuilder implementations MUST have a public no-arg constructor | 
| Uses of Configurable in org.apache.flume.source | 
|---|
| Classes in org.apache.flume.source that implement Configurable | |
|---|---|
|  class | AbstractEventDrivenSourceBase class which ensures sub-classes will inherit all the properties of BasicSourceSemantics. | 
|  class | AbstractPollableSourceBase class which ensures sub-classes will inherit all the properties of BasicSourceSemantics in addition to: Ensuring when configure/start throw an exception process will not be called Ensure that process will not be called unless configure and start have successfully been called | 
|  class | AvroSourceA Sourceimplementation that receives Avro events from clients that
 implementAvroSourceProtocol. | 
|  class | BasicSourceSemanticsAlternative to AbstractSource, which: Ensure configure cannot be called while started Exceptions thrown during configure, start, stop put source in ERROR state Exceptions thrown during start, stop will be logged but not re-thrown. Exception in configure disables starting | 
|  class | ExecSourceA Sourceimplementation that executes a Unix process and turns each
 line of text into an event. | 
|  class | MultiportSyslogTCPSource | 
|  class | NetcatSourceA netcat-like source that listens on a given port and turns each line of text into an event. | 
|  class | SequenceGeneratorSource | 
|  class | SpoolDirectorySource | 
|  class | StressSourceInternal load-generating source implementation. | 
|  class | SyslogTcpSource | 
|  class | SyslogUDPSource | 
|  class | ThriftSource | 
| Uses of Configurable in org.apache.flume.source.avroLegacy | 
|---|
| Classes in org.apache.flume.source.avroLegacy that implement Configurable | |
|---|---|
|  class | AvroLegacySourceA Sourceimplementation that receives Avro events from Avro sink of
 Flume OG | 
| Uses of Configurable in org.apache.flume.source.http | 
|---|
| Subinterfaces of Configurable in org.apache.flume.source.http | |
|---|---|
|  interface | HTTPSourceHandler | 
| Classes in org.apache.flume.source.http that implement Configurable | |
|---|---|
|  class | HTTPSourceA source which accepts Flume Events by HTTP POST and GET. | 
|  class | JSONHandlerJSONHandler for HTTPSource that accepts an array of events. | 
| Uses of Configurable in org.apache.flume.source.jms | 
|---|
| Classes in org.apache.flume.source.jms that implement Configurable | |
|---|---|
|  class | JMSSource | 
| Uses of Configurable in org.apache.flume.source.scribe | 
|---|
| Classes in org.apache.flume.source.scribe that implement Configurable | |
|---|---|
|  class | ScribeSourceFlume should adopt the Scribe entry LogEntryfrom existing
 Scribe system. | 
| Uses of Configurable in org.apache.flume.source.thriftLegacy | 
|---|
| Classes in org.apache.flume.source.thriftLegacy that implement Configurable | |
|---|---|
|  class | ThriftLegacySource | 
| Uses of Configurable in org.apache.flume.source.twitter | 
|---|
| Classes in org.apache.flume.source.twitter that implement Configurable | |
|---|---|
|  class | TwitterSourceDemo Flume source that connects via Streaming API to the 1% sample twitter firehose, continously downloads tweets, converts them to Avro format and sends Avro events to a downstream Flume sink. | 
| 
 | ||||||||||
| PREV NEXT | FRAMES NO FRAMES | |||||||||