Uses of Interface
org.apache.flume.conf.Configurable

Packages that use Configurable
org.apache.flume   
org.apache.flume.agent.embedded This package provides Flume users the ability to embed simple agents in applications. 
org.apache.flume.channel   
org.apache.flume.channel.file   
org.apache.flume.channel.jdbc   
org.apache.flume.channel.kafka   
org.apache.flume.instrumentation   
org.apache.flume.instrumentation.http   
org.apache.flume.interceptor   
org.apache.flume.serialization   
org.apache.flume.sink   
org.apache.flume.sink.elasticsearch   
org.apache.flume.sink.elasticsearch.client   
org.apache.flume.sink.hbase   
org.apache.flume.sink.hdfs   
org.apache.flume.sink.hive   
org.apache.flume.sink.irc   
org.apache.flume.sink.kafka   
org.apache.flume.sink.kite   
org.apache.flume.sink.solr.morphline   
org.apache.flume.source   
org.apache.flume.source.avroLegacy   
org.apache.flume.source.http   
org.apache.flume.source.jms   
org.apache.flume.source.kafka   
org.apache.flume.source.scribe   
org.apache.flume.source.thriftLegacy   
org.apache.flume.source.twitter   
org.apache.flume.tools   
 

Uses of Configurable in org.apache.flume
 

Subinterfaces of Configurable in org.apache.flume
 interface ChannelSelector
           Allows the selection of a subset of channels from the given set based on its implementation policy.
 interface SinkProcessor
           Interface 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 EmbeddedSource
          Simple 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 BasicChannelSemantics
           An implementation of basic Channel semantics, including the implied thread-local semantics of the Transaction class, which is required to extend BasicTransactionSemantics.
 class ChannelProcessor
          A channel processor exposes operations to put Events into Channels.
 class MemoryChannel
           MemoryChannel 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 PseudoTxnMemoryChannel
           A capacity-capped Channel implementation that supports in-memory buffering and delivery of events.
 class ReplicatingChannelSelector
          Replicating channel selector.
 class SpillableMemoryChannel
           SpillableMemoryChannel 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 FileChannel
           A durable Channel implementation 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 JdbcChannel
           A JDBC based channel implementation.
 

Uses of Configurable in org.apache.flume.channel.kafka
 

Classes in org.apache.flume.channel.kafka that implement Configurable
 class KafkaChannel
           
 

Uses of Configurable in org.apache.flume.instrumentation
 

Subinterfaces of Configurable in org.apache.flume.instrumentation
 interface MonitorService
          Interface that any monitoring service should implement.
 

Classes in org.apache.flume.instrumentation that implement Configurable
 class GangliaServer
          A 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 HTTPMetricsServer
          A 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.Builder
          Builder implementations MUST have a no-arg constructor
 interface RegexExtractorInterceptorSerializer
          Serializer for serializing groups matched by the RegexExtractorInterceptor
 

Classes in org.apache.flume.interceptor that implement Configurable
static class HostInterceptor.Builder
          Builder which builds new instances of the HostInterceptor.
static class RegexExtractorInterceptor.Builder
           
 class RegexExtractorInterceptorMillisSerializer
          Serializer that converts the passed in value into milliseconds using the specified formatting pattern
 class RegexExtractorInterceptorPassThroughSerializer
          Serializer that simply returns the passed in value
static class RegexFilteringInterceptor.Builder
          Builder which builds new instance of the StaticInterceptor.
static class SearchAndReplaceInterceptor.Builder
           
static class StaticInterceptor.Builder
          Builder which builds new instance of the StaticInterceptor.
static class TimestampInterceptor.Builder
          Builder 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.SinkSelector
           An 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 AbstractRpcSink
          This sink provides the basic RPC functionality for Flume.
 class AbstractSinkProcessor
          A convenience base class for sink processors.
 class AbstractSinkSelector
           
 class AvroSink
           A Sink implementation that can send events to an RPC server (such as Flume's AvroSource).
 class DefaultSinkProcessor
          Default sink processor that only accepts a single sink, passing on process results without any additional handling.
 class FailoverSinkProcessor
          FailoverSinkProcessor maintains a prioritized list of sinks, guarranteeing that so long as one is available events will be processed.
 class LoadBalancingSinkProcessor
          Provides the ability to load-balance flow over multiple sinks.
 class LoggerSink
           A Sink implementation that logs all events received at the INFO level to the org.apache.flume.sink.LoggerSink logger.
 class NullSink
           A Sink implementation that simply discards all events it receives.
 class RollingFileSink
           
 class SinkGroup
          Configuration concept for handling multiple sinks working together.
 class ThriftSink
           A Sink implementation that can send events to an RPC server (such as Flume's ThriftSource).
 

Uses of Configurable in org.apache.flume.sink.elasticsearch
 

Subinterfaces of Configurable in org.apache.flume.sink.elasticsearch
 interface ElasticSearchEventSerializer
          Interface for an event serializer which serializes the headers and body of an event to write them to ElasticSearch.
 interface ElasticSearchIndexRequestBuilderFactory
          Interface for creating ElasticSearch IndexRequestBuilder instances from serialized flume events.
 interface IndexNameBuilder
           
 

Classes in org.apache.flume.sink.elasticsearch that implement Configurable
 class AbstractElasticSearchIndexRequestBuilderFactory
          Abstract base class for custom implementations of ElasticSearchIndexRequestBuilderFactory.
 class ElasticSearchDynamicSerializer
          Basic serializer that serializes the event body and header fields into individual fields
 class ElasticSearchLogStashEventSerializer
          Serialize flume events into the same format LogStash uses
 class ElasticSearchSink
          A 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 EventSerializerIndexRequestBuilderFactory
          Default implementation of ElasticSearchIndexRequestBuilderFactory.
 class SimpleIndexNameBuilder
           
 class TimeBasedIndexNameBuilder
          Default index name builder.
 

Uses of Configurable in org.apache.flume.sink.elasticsearch.client
 

Subinterfaces of Configurable in org.apache.flume.sink.elasticsearch.client
 interface ElasticSearchClient
          Interface 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 ElasticSearchRestClient
          Rest 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 AsyncHbaseEventSerializer
          Interface for an event serializer which serializes the headers and body of an event to write them to hbase.
 interface HbaseEventSerializer
          Interface 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 AsyncHBaseSink
          A simple sink which reads events from a channel and writes them to HBase.
 class HBaseSink
          A simple sink which reads events from a channel and writes them to HBase.
 class RegexHbaseEventSerializer
          An HbaseEventSerializer which parses columns based on a supplied regular expression and column name list.
 class SimpleAsyncHbaseEventSerializer
          A simple serializer to be used with the AsyncHBaseSink that returns puts from an event, by writing the event body into it.
 class SimpleHbaseEventSerializer
          A 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 AvroEventSerializer
           This class serializes Flume events into Avro data files.
 class HDFSCompressedDataStream
           
 class HDFSDataStream
           
 class HDFSEventSink
           
 class HDFSSequenceFile
           
 

Uses of Configurable in org.apache.flume.sink.hive
 

Subinterfaces of Configurable in org.apache.flume.sink.hive
 interface HiveEventSerializer
           
 

Classes in org.apache.flume.sink.hive that implement Configurable
 class HiveDelimitedTextSerializer
          Forwards the incoming event body to Hive unmodified Sets up the delimiter and the field to column mapping
 class HiveJsonSerializer
          Forwards the incoming event body to Hive unmodified Sets up the delimiter and the field to column mapping
 class HiveSink
           
 

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.kafka
 

Classes in org.apache.flume.sink.kafka that implement Configurable
 class KafkaSink
          A Flume Sink that can publish messages to Kafka.
 

Uses of Configurable in org.apache.flume.sink.kite
 

Classes in org.apache.flume.sink.kite that implement Configurable
 class DatasetSink
          Sink that writes events to a Kite Dataset.
 

Uses of Configurable in org.apache.flume.sink.solr.morphline
 

Subinterfaces of Configurable in org.apache.flume.sink.solr.morphline
 interface MorphlineHandler
          Interface to load Flume events into Solr
 

Classes in org.apache.flume.sink.solr.morphline that implement Configurable
 class BlobHandler
          BlobHandler for HTTPSource that returns event that contains the request parameters as well as the Binary Large Object (BLOB) uploaded with this request.
 class MorphlineHandlerImpl
          A MorphlineHandler that processes it's events using a morphline Command chain.
static class MorphlineInterceptor.Builder
          Builder implementations MUST have a public no-arg constructor
 class MorphlineSink
          Flume sink that extracts search documents from Flume events and processes them using a morphline Command chain.
 class MorphlineSolrSink
          Flume sink that extracts search documents from Flume events, processes them using a morphline Command chain, and loads them into Apache Solr.
static class UUIDInterceptor.Builder
          Builder 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 AbstractEventDrivenSource
          Base class which ensures sub-classes will inherit all the properties of BasicSourceSemantics.
 class AbstractPollableSource
          Base 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 AvroSource
           A Source implementation that receives Avro events from clients that implement AvroSourceProtocol.
 class BasicSourceSemantics
          Alternative 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 ExecSource
           A Source implementation that executes a Unix process and turns each line of text into an event.
 class MultiportSyslogTCPSource
           
 class NetcatSource
           A netcat-like source that listens on a given port and turns each line of text into an event.
 class SequenceGeneratorSource
           
 class SpoolDirectorySource
           
 class StressSource
          StressSource is an internal load-generating source implementation which is very useful for stress tests.
 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 AvroLegacySource
           A Source implementation 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 HTTPSource
          A source which accepts Flume Events by HTTP POST and GET.
 class JSONHandler
          JSONHandler 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.kafka
 

Classes in org.apache.flume.source.kafka that implement Configurable
 class KafkaSource
          A Source for Kafka which reads messages from a kafka topic.
 

Uses of Configurable in org.apache.flume.source.scribe
 

Classes in org.apache.flume.source.scribe that implement Configurable
 class ScribeSource
          Flume should adopt the Scribe entry LogEntry from 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 TwitterSource
          Demo 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.
 

Uses of Configurable in org.apache.flume.tools
 

Subinterfaces of Configurable in org.apache.flume.tools
static interface EventValidator.Builder
           
 



Copyright © 2009-2015 Apache Software Foundation. All Rights Reserved.