Example usage for org.apache.hadoop.conf Configurable interface-usage

List of usage examples for org.apache.hadoop.conf Configurable interface-usage

Introduction

In this page you can find the example usage for org.apache.hadoop.conf Configurable interface-usage.

Usage

From source file colossal.pipe.ColMapper.java

public interface ColMapper<IN, OUT> extends Configurable {
    public void map(IN in, OUT out, ColContext<OUT> context);

    public void close(OUT out, ColContext<OUT> context);
}

From source file colossal.pipe.ColReducer.java

public interface ColReducer<IN, OUT> extends Configurable {
    public void reduce(Iterable<IN> in, OUT out, ColContext<OUT> context);

    public void close(OUT out, ColContext<OUT> context);
}

From source file com.alibaba.wasp.ipc.Transceiver.java

/** Base transport class used by ClientCache}. */
public abstract class Transceiver implements Closeable, Configurable {
    private final ReentrantLock channelLock = new ReentrantLock();

    public abstract String getRemoteName() throws IOException;

From source file com.alibaba.wasp.master.LoadBalancer.java

/**
 * Makes decisions about the placement and movement of EntityGroups across
 * FServers.
 * 
 * <p>
 * Cluster-wide load balancing will occur only when there are no entityGroups in

From source file com.alibaba.wasp.meta.FMetaServices.java

/**
 * Meta Store operation services interface, including create\drop\alter\get
 * Table, alter table including column\index\EntityGroup related operation
 * */
public abstract class FMetaServices extends Configured implements Configurable {

From source file com.alibaba.wasp.meta.TableSchemaCacheReader.java

/**
 * 
 * Local cache for table schema information, used by FServer.
 * 
 * If the meta is NOT fresh,fServer will received the news,then update the
 * TableSchemaReader.

From source file com.alibaba.wasp.plan.action.Action.java

/**
 * basic Action.
 */
public abstract class Action implements Configurable {

    private Configuration conf;

From source file com.alibaba.wasp.plan.parser.druid.DruidParser.java

/**
 * Use Druid (https://github.com/AlibabaTech/druid) to parse the sql and
 * generate QueryPlan
 * 
 */
public abstract class DruidParser extends Parser implements Configurable {

From source file com.alibaba.wasp.WaspCluster.java

/**
 * This class defines methods that can help with managing Wasp clusters from
 * unit tests and system tests. There are 1 type of cluster deployments:
 * <ul>
 * <li><b>MiniWaspCluster:</b> each server is run in the same JVM in separate
 * threads, used by unit tests</li>

From source file com.ambiata.ivory.operation.hadoop.TaggedInputSplit.java

/**
 * An {@link InputSplit} that tags another InputSplit with extra data for use
 * by {@link DelegatingInputFormat}s and {@link DelegatingMapper}s.
 */
public /* WAS: package protected */ class TaggedInputSplit extends InputSplit implements Configurable, Writable {